2025.10.23 23:23:26.410389 [ 411 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:23:26.412164 [ 411 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.10.23 23:23:26.983463 [ 411 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:23:26.992158 [ 411 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:23:33.142104 [ 411 ] {} KeeperLogStore: No logs exists in /var/lib/clickhouse/coordination/logs. It's Ok if it's the first run of clickhouse-keeper. 2025.10.23 23:23:33.148974 [ 411 ] {} KeeperLogStore: Removing all changelogs 2025.10.23 23:23:33.163261 [ 411 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:23:33.182144 [ 411 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:23:33.182969 [ 411 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:23:33.250495 [ 1036 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:23:34.175428 [ 411 ] {} Access(local_directory): File /var/lib/clickhouse/access/users.list doesn't exist 2025.10.23 23:23:34.176247 [ 411 ] {} Access(local_directory): Recovering lists in directory /var/lib/clickhouse/access/ 2025.10.23 23:23:34.938897 [ 411 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:23:39.619894 [ 414 ] {8689c320-fe3a-4650-8067-04e055e67db8} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE hits_v1; to attach existing table or CREATE TABLE hits_v1 ; to create new table or ATTACH TABLE hits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.10.23 23:23:53.805159 [ 414 ] {8d567ae7-98dd-4a85-8f0e-4de4737a7858} InterpreterCreateQuery: ATTACH TABLE query with full table definition is not recommended: use either ATTACH TABLE visits_v1; to attach existing table or CREATE TABLE visits_v1
; to create new table or ATTACH TABLE visits_v1 FROM '/path/to/data/'
; to create new table and attach data. 2025.10.23 23:24:06.341208 [ 1041 ] {} RaftInstance: failed to accept a rpc connection due to error 125, Operation canceled 2025.10.23 23:24:12.245922 [ 1288 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:24:12.247704 [ 1288 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.10.23 23:24:12.565820 [ 1288 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:24:12.570779 [ 1288 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:24:18.005713 [ 1288 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:24:18.103688 [ 1288 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:24:18.104767 [ 1288 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:24:18.168373 [ 1907 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:24:27.174685 [ 1288 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:25:20.959134 [ 1291 ] {feb79535-f868-4927-9ff0-8eef3a94d50c} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1982336 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (avg_value_size_hint = 80.75439453125, avg_chars_size = 87.30527343749999, limit = 8192): (while reading column Params): (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 380 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36428) (in query: INSERT INTO test.hits_s3 SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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>&&) @ 0x000000001ae006bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfee3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 9. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c19319 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c8162fe 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c81506d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 20. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007fef3cff5ac3 30. ? @ 0x00007fef3d087850 2025.10.23 23:25:33.489663 [ 1291 ] {feb79535-f868-4927-9ff0-8eef3a94d50c} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1982336 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (avg_value_size_hint = 80.75439453125, avg_chars_size = 87.30527343749999, limit = 8192): (while reading column Params): (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 380 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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>&&) @ 0x000000001ae006bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfee3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 9. ./src/Common/PODArray.h:120: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c19319 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c8162fe 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c81506d 13. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 14. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 15. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 17. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 18. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 19. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 20. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 21. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 22. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 25. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007fef3cff5ac3 30. ? @ 0x00007fef3d087850 2025.10.23 23:25:55.062234 [ 1291 ] {028125d3-440f-4c57-88b2-918b171d5394} executeQuery: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1839760 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column MobilePhone): (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 768 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53222) (in query: INSERT INTO test.hits SELECT * FROM datasets.hits_v1 SETTINGS enable_filesystem_cache_on_write_operations=0, max_insert_threads=16), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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>&&) @ 0x000000001ae006bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfee3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 9. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000001aeaea60 10. ./build_docker/./src/Disks/IO/AsynchronousBoundedReadBuffer.cpp:0: DB::AsynchronousBoundedReadBuffer::prefetch(Priority) @ 0x0000000026a8cea7 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c819454 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c814395 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c8139cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c814b7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:26:06.919824 [ 1291 ] {028125d3-440f-4c57-88b2-918b171d5394} TCPHandler: Code: 241. DB::Exception: Memory limit (for user) exceeded: would use 9.18 GiB (attempt to allocate chunk of 1839760 bytes), maximum: 9.18 GiB. OvercommitTracker decision: Query was selected to stop by OvercommitTracker.: (while reading column MobilePhone): (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 768 with max_rows_to_read = 8192): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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>&&) @ 0x000000001ae006bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfee3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 7. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 8. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 9. ./src/IO/BufferWithOwnMemory.h:130: DB::Memory>::alloc(unsigned long) @ 0x000000001aeaea60 10. ./build_docker/./src/Disks/IO/AsynchronousBoundedReadBuffer.cpp:0: DB::AsynchronousBoundedReadBuffer::prefetch(Priority) @ 0x0000000026a8cea7 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c819454 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c814395 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c8139cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c814b7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:26:58.835027 [ 2717 ] {} Context: ThreadFuzzer is enabled. Application will run slowly and unstable. 2025.10.23 23:26:58.836634 [ 2717 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.10.23 23:26:59.229434 [ 2717 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.10.23 23:26:59.231940 [ 2717 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:26:59.240289 [ 2717 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:27:06.346304 [ 2717 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:27:06.369343 [ 2717 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:27:06.370365 [ 2717 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:27:06.433802 [ 3349 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:27:15.921115 [ 2717 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:27:18.149268 [ 2720 ] {7f0e2378-914a-47b7-892f-23d5bd57eea9} 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.10542.altinitytest (altinity build)) (from [::1]:52022) (in query: SELECT count() FROM system.build_options WHERE name = 'CXX_FLAGS' AND position('sanitize=address' IN value)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:18.174448 [ 2720 ] {7f0e2378-914a-47b7-892f-23d5bd57eea9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:23.338938 [ 3378 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3d81872f-1b54-4b63-aeed-f859059173ca::202510_1_26_5}: 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:24.471325 [ 2722 ] {30b8bc31-62a3-41b3-90bc-c3660fec0b97} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33090) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:27:24.478019 [ 2722 ] {30b8bc31-62a3-41b3-90bc-c3660fec0b97} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:25.465464 [ 2722 ] {b5f83862-f27e-4cff-b0ff-0fb1cba7fd49} 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.10542.altinitytest (altinity build)) (from [::1]:33124) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d361f3e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4cb30 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:27:25.470430 [ 2722 ] {b5f83862-f27e-4cff-b0ff-0fb1cba7fd49} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d361f3e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4cb30 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:27.317692 [ 3689 ] {3aeef2b5-a53c-478a-9752-37c00e15025f} 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.10542.altinitytest (altinity build)) (from [::1]:33286) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d361f3e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4cb30 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:27:27.321798 [ 3689 ] {3aeef2b5-a53c-478a-9752-37c00e15025f} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d361f3e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4cb30 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:27.907862 [ 3654 ] {0eabd4fa-7c73-4b60-b43b-8f5474aaf20c} 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.10542.altinitytest (altinity build)) (from [::1]:33348) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:27:27.913342 [ 3654 ] {0eabd4fa-7c73-4b60-b43b-8f5474aaf20c} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:28.435176 [ 3654 ] {c58117e9-0419-47d1-a27b-bc99406e4496} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33380) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:27:28.439027 [ 3654 ] {c58117e9-0419-47d1-a27b-bc99406e4496} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:29.291703 [ 3689 ] {22d70858-4579-4bcd-a8a0-bb6ac2c94e5c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33496) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:27:29.296265 [ 3689 ] {22d70858-4579-4bcd-a8a0-bb6ac2c94e5c} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:29.798821 [ 2720 ] {63fb6851-eb23-42e6-8159-8acd90cf7a26} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=721, jobs=706). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35138) (comment: 02292_h3_unidirectional_funcs.sql) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge(1248204388774707199);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:29.801578 [ 2720 ] {63fb6851-eb23-42e6-8159-8acd90cf7a26} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=721, jobs=706). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:31.506738 [ 3677 ] {38f5d80c-6e8f-482f-9e1f-8252657b8f4f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33704) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d361f3e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4cb30 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:27:31.523109 [ 3677 ] {38f5d80c-6e8f-482f-9e1f-8252657b8f4f} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:113: DB::CompletedPipelineExecutor::execute() @ 0x000000002d361f3e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1635: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4cb30 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:31.887226 [ 3660 ] {caa1a98d-7fa3-4a47-943c-4d876563849c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33756) (in query: SELECT version(), arrayStringConcat(groupArray(value), ' ') FROM system.build_options WHERE name IN ('GIT_HASH', 'GIT_BRANCH') ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:27:31.896130 [ 3660 ] {caa1a98d-7fa3-4a47-943c-4d876563849c} DynamicQueryHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:32.686333 [ 3856 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:56600, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0ba0a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0babe4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf20db6 6. DB::ReadBuffer::next() @ 0x000000000b52caeb 7. ./src/IO/ReadBuffer.h:0: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x000000001aeaa4aa 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001aefa5d2 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000002d1a318b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d190a00 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:35.801005 [ 3875 ] {156ac589-bfd2-4516-a81a-c883cefd81c8} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.0438781 seconds, maximum: 1. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35224) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000278629ba 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027861124 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d3649af 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 9. asan_thread_start(void*) @ 0x000000000aa47059 10. ? @ 0x00007f7519d19ac3 11. ? @ 0x00007f7519dab850 2025.10.23 23:27:35.811246 [ 3875 ] {156ac589-bfd2-4516-a81a-c883cefd81c8} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 2.0438781 seconds, maximum: 1. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000278629ba 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027861124 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d3649af 6. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 9. asan_thread_start(void*) @ 0x000000000aa47059 10. ? @ 0x00007f7519d19ac3 11. ? @ 0x00007f7519dab850 2025.10.23 23:27:35.877595 [ 3654 ] {d083492c-ca34-4f03-a392-069993b975b6} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:35172) (comment: 02420_final_setting.sql) (in query: -- expected output is 1 because final is turned on select count() from replacing_mt;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:35.890315 [ 3654 ] {d083492c-ca34-4f03-a392-069993b975b6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:36.824116 [ 4049 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:35218, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0ba0a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0babe4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf20db6 6. DB::ReadBuffer::next() @ 0x000000000b52caeb 7. ./src/IO/ReadBuffer.h:0: void DB::varint_impl::readVarUInt(unsigned long&, DB::ReadBuffer&) @ 0x000000001aeaa4aa 8. ./src/IO/ReadHelpers.h:143: DB::readStringBinary(String&, DB::ReadBuffer&, unsigned long) @ 0x000000001aefa5d2 9. ./build_docker/./src/Server/TCPHandler.cpp:1653: DB::TCPHandler::receiveAddendum() @ 0x000000002d1a318b 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d190a00 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:37.687616 [ 3677 ] {2a25f385-c093-4d63-9c72-3e2ead7a733e} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48168) (comment: 02989_system_tables_metadata_version.sql) (in query: ALTER TABLE test_table_replicated ADD COLUMN insert_time DateTime;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000291958fe 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e112 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:37.706782 [ 3677 ] {2a25f385-c093-4d63-9c72-3e2ead7a733e} TCPHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000291958fe 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e112 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:38.143642 [ 2722 ] {3a3f4f5e-dd12-461f-9a48-9697cbe5d0cd} executeQuery: Code: 48. DB::Exception: ReplicatedMergeTree (table test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3)) does not support transactions. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37322) (comment: 02989_system_tables_metadata_version.sql) (in query: DROP DATABASE IF EXISTS test_d4i092zk ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000291958fe 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd661 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:27:38.149547 [ 2722 ] {3a3f4f5e-dd12-461f-9a48-9697cbe5d0cd} DynamicQueryHandler: Code: 48. DB::Exception: ReplicatedMergeTree (table test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3)) does not support transactions. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/IInterpreter.cpp:50: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000291958fe 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd661 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 12. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 13. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 14. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:42.127161 [ 4076 ] {003dba15-554e-4e83-858d-75a35bcda353} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60618) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:27:42.150625 [ 4076 ] {003dba15-554e-4e83-858d-75a35bcda353} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:27:42.154797 [ 2970 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:42.201204 [ 4203 ] {da4a079b-43c0-448e-9128-798de22f88d4} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48288) (comment: 00020_distinct_order_by_distributed.sql) (in query: SELECT count() FROM (SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfb3e3e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:27:42.218549 [ 4203 ] {da4a079b-43c0-448e-9128-798de22f88d4} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.2:9000. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfb3e3e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:27:42.610671 [ 3856 ] {b2de0795-bc2e-4b38-8725-ca909d8f701a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48198) (comment: 02842_mutations_replace_non_deterministic.sql) (in query: SELECT id, v FROM t_mutations_nondeterministic ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:27:42.624078 [ 3856 ] {b2de0795-bc2e-4b38-8725-ca909d8f701a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:27:43.157280 [ 3000 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:44.159584 [ 3030 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:45.171077 [ 3056 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:46.066403 [ 4076 ] {f67001b4-cc4c-4018-86cc-a6af9e7c99e6} 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.10542.altinitytest (altinity build)) (from [::1]:59304) (comment: 01281_sum_nullable.sql) (in query: SELECT sum(toNullable(number)) FROM numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:46.071116 [ 4076 ] {f67001b4-cc4c-4018-86cc-a6af9e7c99e6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:46.182289 [ 3092 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:46.746420 [ 4294 ] {e82aa474-1dc3-4b11-b749-1239f2986938} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59316) (comment: 00172_early_constant_folding.sql) (in query: EXPLAIN PIPELINE SELECT count(JavaEnable) FROM test.hits WHERE WatchID = 1 OR Title = 'next' OR URL = 'prev' OR URL = '???' OR 1 SETTINGS enable_analyzer = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f857c3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002854616d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000295030e1 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000295046ad 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000295037e1 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000029503e19 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b406c4 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:27:46.776843 [ 4294 ] {e82aa474-1dc3-4b11-b749-1239f2986938} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f857c3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002854616d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::executeForCurrentContext(bool) @ 0x00000000295030e1 9. ./src/Interpreters/InterpreterSetQuery.h:14: DB::applySettingsFromSelectWithUnion(DB::ASTSelectWithUnionQuery const&, std::shared_ptr) @ 0x00000000295046ad 10. ./build_docker/./src/Interpreters/InterpreterSetQuery.cpp:65: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x00000000295037e1 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::applySettingsFromQuery(std::shared_ptr const&, std::shared_ptr) @ 0x0000000029503e19 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b406c4 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:27:47.226365 [ 3124 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:48.033087 [ 4049 ] {f29f7525-0165-4d99-876b-7eb2ebc615c0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:40974) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:48.044202 [ 4293 ] {e373a5d8-7782-411d-9621-c6d0722af7ae} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:35456) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:48.044482 [ 4049 ] {f29f7525-0165-4d99-876b-7eb2ebc615c0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:48.065616 [ 4293 ] {e373a5d8-7782-411d-9621-c6d0722af7ae} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:48.228697 [ 3157 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:48.263862 [ 2722 ] {519c94ea-e3c4-4da0-910b-63af6ee90b64} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59324) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT SearchPhrase AS k, count() AS c FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) GROUP BY k ORDER BY c DESC LIMIT 10), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfb3e3e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:27:48.299712 [ 3654 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:37870, local: [::ffff:127.0.0.7]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0ba0a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0babe4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf20db6 6. DB::ReadBuffer::next() @ 0x000000000b52caeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d191773 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:48.301554 [ 4293 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:35456, local: [::ffff:127.0.0.6]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0ba0a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0babe4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf20db6 6. DB::ReadBuffer::next() @ 0x000000000b52caeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d191773 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:48.321493 [ 4203 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:48602, local: [::ffff:127.0.0.4]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0ba0a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0babe4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf20db6 6. DB::ReadBuffer::next() @ 0x000000000b52caeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d191773 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:48.341394 [ 2722 ] {519c94ea-e3c4-4da0-910b-63af6ee90b64} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.5:9000. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfb3e3e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:27:48.450050 [ 4419 ] {972aaf17-4d53-40eb-a041-edd4143834e0} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:53860). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53860) (comment: 00090_thread_pool_deadlock.sh) (in query: SELECT `__table1`.`SearchPhrase` AS `k`, count() AS `c` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`SearchPhrase` ORDER BY count() DESC LIMIT _CAST(10, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d1aab0e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192ef7 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:48.495926 [ 4419 ] {972aaf17-4d53-40eb-a041-edd4143834e0} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:53860). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:48.504173 [ 4419 ] {972aaf17-4d53-40eb-a041-edd4143834e0} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.9]:9000 -> [::ffff:127.0.0.1]:53860). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d1aab0e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192ef7 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:48.509164 [ 4419 ] {972aaf17-4d53-40eb-a041-edd4143834e0} TCPHandler: Client has gone away. 2025.10.23 23:27:49.232153 [ 3190 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:50.234503 [ 3218 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:50.340022 [ 3677 ] {ab94b62e-3684-43a8-b7ef-b08c8378826a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59386) (comment: 00664_cast_from_string_to_nullable.sql) (in query: SELECT toDateOrZero(arrayJoin(['', '2018', '2018-01-02', '2018-1-2', '2018-01-2', '2018-1-02', '2018-ab-cd', '2018-01-02a']));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:50.354664 [ 3677 ] {ab94b62e-3684-43a8-b7ef-b08c8378826a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:51.237748 [ 3242 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:52.243822 [ 3274 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:53.247527 [ 2801 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:54.096944 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:27:54.151089 [ 3856 ] {5d8ac1c1-23f2-4d35-81e5-a06118d9f0ce} executeQuery: Code: 6. DB::Exception: Cannot parse string '0.Aa234' as Float64: syntax error at position 2 (parsed just '0.'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toFloat64(__table1.a :: 2) -> toFloat64(__table1.a) Float64 : 1': while pushing to view test_13.matview_exception_a_to_b (31640a5e-4d5e-4fe8-b6dc-3824f5061628). (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59460) (comment: 01927_query_views_log_matview_exceptions.sh) (in query: INSERT INTO table_exception_a VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. 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&&) @ 0x000000000afd4700 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afc2bb6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9df34e 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49e43f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d33fff9 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db9587b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9de73e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9ddef1 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9dd405 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d1a6573 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192b98 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:27:54.186957 [ 3856 ] {5d8ac1c1-23f2-4d35-81e5-a06118d9f0ce} TCPHandler: Code: 6. DB::Exception: Cannot parse string '0.Aa234' as Float64: syntax error at position 2 (parsed just '0.'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toFloat64(__table1.a :: 2) -> toFloat64(__table1.a) Float64 : 1': while pushing to view test_13.matview_exception_a_to_b (31640a5e-4d5e-4fe8-b6dc-3824f5061628). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. 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&&) @ 0x000000000afd4700 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afc2bb6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9df34e 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49e43f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d33fff9 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db9587b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9de73e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9ddef1 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9dd405 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d1a6573 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192b98 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:27:54.250103 [ 2831 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:54.702969 [ 3856 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:27:55.252092 [ 2857 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:55.453155 [ 3856 ] {b4f5d014-208d-429c-8592-0e0ad26de455} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46984) (comment: 01554_interpreter_integer_float.sql) (in query: SELECT reinterpretAsFloat32(CAST(123456 AS UInt32));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:55.462479 [ 3856 ] {b4f5d014-208d-429c-8592-0e0ad26de455} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:27:55.789597 [ 3856 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:27:56.260335 [ 2904 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:56.938910 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:27:57.262481 [ 2930 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:57.525475 [ 4203 ] {edd7b400-53b7-43e6-a769-dbbbc3ac6b64} 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.10542.altinitytest (altinity build)) (from [::1]:47034) (comment: 00022_merge_prewhere.sql) (in query: SELECT count() FROM test.merge_hits PREWHERE AdvEngineID = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:57.528298 [ 4203 ] {edd7b400-53b7-43e6-a769-dbbbc3ac6b64} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:27:58.078289 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:27:58.265355 [ 2966 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:59.115116 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:27:59.268575 [ 2987 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:27:59.666463 [ 4049 ] {6abda015-8710-48b3-b069-b7e9a4bf07a5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47122) (comment: 01927_query_views_log_matview_exceptions.sh) (in query: SELECT view_name, replaceOne(CAST(status AS String), 'ExceptionWhileProcessing', 'Excep****WhileProcessing'), exception_code, view_target, view_query FROM system.query_views_log WHERE initial_query_id = ( SELECT query_id FROM system.query_log WHERE current_database = 'test_13' AND query LIKE 'INSERT INTO table_exception_a%' AND type > 0 AND event_date >= yesterday() AND current_database = currentDatabase() ORDER BY event_time_microseconds DESC LIMIT 1 ) ORDER BY view_name ASC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:27:59.677052 [ 4049 ] {6abda015-8710-48b3-b069-b7e9a4bf07a5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:28:00.203360 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:00.359347 [ 3017 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:00.403011 [ 4289 ] {fb13d004-d38e-42ab-b4fd-b87615595521} ExternalDictionariesLoader: Could not load external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', next update is scheduled at 2025-10-23 23:28:06: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:00.409632 [ 4203 ] {fb13d004-d38e-42ab-b4fd-b87615595521} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47096) (comment: 01910_view_dictionary_check_refresh.sql) (in query: select 'dict' src,* FROM TestTblDict ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:28:00.420580 [ 4203 ] {fb13d004-d38e-42ab-b4fd-b87615595521} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:28:00.694481 [ 4415 ] {19c313b8-306f-4f74-bf9f-533e5b5ed1f2} executeQuery: Code: 6. DB::Exception: Cannot parse string '0.Aa234' as Float64: syntax error at position 2 (parsed just '0.'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toFloat64(__table1.a :: 2) -> toFloat64(__table1.a) Float64 : 1': while pushing to view test_13.matview_exception_a_to_b (31640a5e-4d5e-4fe8-b6dc-3824f5061628). (CANNOT_PARSE_TEXT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47152) (comment: 01927_query_views_log_matview_exceptions.sh) (in query: INSERT INTO table_exception_a VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. 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&&) @ 0x000000000afd4700 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afc2bb6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9df34e 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49e43f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d33fff9 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db9587b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9de73e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9ddef1 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9dd405 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d1a6573 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192b98 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:00.703456 [ 4415 ] {19c313b8-306f-4f74-bf9f-533e5b5ed1f2} TCPHandler: Code: 6. DB::Exception: Cannot parse string '0.Aa234' as Float64: syntax error at position 2 (parsed just '0.'). Note: there are toFloat64OrZero and toFloat64OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION toFloat64(__table1.a :: 2) -> toFloat64(__table1.a) Float64 : 1': while pushing to view test_13.matview_exception_a_to_b (31640a5e-4d5e-4fe8-b6dc-3824f5061628). (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. 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&&) @ 0x000000000afd4700 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToFloat64, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000afc2bb6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 11. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9df34e 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49e43f 13. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d33fff9 14. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 17. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 18. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:776: DB::ExecutingInnerQueryFromViewTransform::onGenerate() @ 0x000000002db9587b 19. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:164: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9de73e 20. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9ddef1 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9dd405 22. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 23. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 25. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d1a6573 26. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192b98 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:01.244857 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:01.316114 [ 4419 ] {cc77257b-d1d8-4a0d-91f5-18d4b6574394} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47142) (comment: 00043_any_left_join.sql) (in query: SELECT EventDate, count() AS hits, any(visits) FROM test.hits ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate GROUP BY EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:28:01.357187 [ 4419 ] {cc77257b-d1d8-4a0d-91f5-18d4b6574394} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:28:01.366649 [ 3047 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:01.858555 [ 2720 ] {cc04efd3-ad10-4ef7-8256-3a725b65cfe1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=724). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47018) (comment: 00087_math_functions.sql) (in query: select tgamma(0) = inf;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:01.874202 [ 2720 ] {cc04efd3-ad10-4ef7-8256-3a725b65cfe1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=724). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:02.291875 [ 3654 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:02.373137 [ 3072 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:03.376535 [ 3104 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:03.411995 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:04.378972 [ 3133 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:04.686033 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:04.708710 [ 3856 ] {8ba72dfa-87ff-4e96-820c-92a9e8d04cab} 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.10542.altinitytest (altinity build)) (from [::1]:47042) (comment: 00074_full_join.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY LEFT JOIN ( SELECT (CounterID % 100000) AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0 ) USING CounterID WHERE hits = 0 OR visits = 0 ORDER BY hits + visits * 10 DESC, CounterID ASC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:28:04.736213 [ 3856 ] {8ba72dfa-87ff-4e96-820c-92a9e8d04cab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:28:05.014579 [ 2722 ] {31d7d34b-787e-407a-8af5-053317826751} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36840) (comment: 01927_query_views_log_matview_exceptions.sh) (in query: SELECT replaceOne(CAST(type AS String), 'ExceptionWhileProcessing', 'Excep****WhileProcessing') exception_code FROM system.query_log WHERE query LIKE 'INSERT INTO table_exception_a%' AND type > 0 AND event_date >= yesterday() AND current_database = currentDatabase() ORDER BY event_time_microseconds DESC LIMIT 1 FORMAT TSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83f17a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:28:05.021740 [ 2722 ] {31d7d34b-787e-407a-8af5-053317826751} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83f17a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:28:05.381570 [ 3165 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:05.781109 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:06.383751 [ 3194 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:06.896806 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:07.385851 [ 3222 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:07.765756 [ 2722 ] {e38cae86-69f2-4aef-8cb6-718085d7b249} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36844) (comment: 01436_storage_merge_with_join_push_down.sql) (in query: DROP TABLE test_merge;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:07.768984 [ 2722 ] {e38cae86-69f2-4aef-8cb6-718085d7b249} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:07.963616 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.388856 [ 3250 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:08.428955 [ 3856 ] {2ce4b918-e7ac-4582-b806-d2393feef4d1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47170) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, quantileTiming(0.5)(`__table1`.`SendTiming`) AS `quantileTiming(0.5)(SendTiming)`, count() AS `count()` FROM `test`.`hits` AS `__table1` WHERE `__table1`.`SendTiming` != -1 GROUP BY `__table1`.`CounterID`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.432131 [ 3856 ] {2ce4b918-e7ac-4582-b806-d2393feef4d1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.583733 [ 3907 ] {022fd2fa-fbd9-4fdb-b45e-0fc32a8b733f} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36864) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT sum(cityHash64(*)) FROM (SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID) SETTINGS optimize_aggregation_in_order = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfb3e3e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:28:08.623452 [ 3907 ] {022fd2fa-fbd9-4fdb-b45e-0fc32a8b733f} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.7:9000. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/PacketReceiver.cpp:0: DB::PacketReceiver::Task::run(std::function, std::function) @ 0x000000002cfb3e3e 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 8. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:28:08.725353 [ 4147 ] {e6811a1f-901f-4533-9a49-a4f87c9bfc97} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:44500). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:44500) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, quantileTiming(0.5)(`__table1`.`SendTiming`) AS `quantileTiming(0.5)(SendTiming)`, count() AS `count()` FROM `test`.`hits` AS `__table1` WHERE `__table1`.`SendTiming` != -1 GROUP BY `__table1`.`CounterID`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7db0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.747227 [ 4147 ] {e6811a1f-901f-4533-9a49-a4f87c9bfc97} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:44500). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:08.764780 [ 4147 ] {e6811a1f-901f-4533-9a49-a4f87c9bfc97} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:44500). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7db0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.770632 [ 4147 ] {e6811a1f-901f-4533-9a49-a4f87c9bfc97} TCPHandler: Client has gone away. 2025.10.23 23:28:08.858686 [ 4049 ] {be5c2b73-c599-4900-9e84-ebe28157905b} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36912) (comment: 02168_avro_bug.sql) (in query: insert into table function file('data.avro', 'Parquet', 'x UInt64') select * from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b7b002f 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000029364754 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.864736 [ 4049 ] {be5c2b73-c599-4900-9e84-ebe28157905b} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b7b002f 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000029364754 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.964223 [ 4049 ] {1641ed2b-0ce9-4ceb-8b8a-0ca436fe43d2} executeQuery: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36912) (comment: 02168_avro_bug.sql) (in query: insert into table function file('data.avro', 'Parquet', 'x UInt64') select * from numbers(10);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b7b002f 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000029364754 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.969645 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:08.969848 [ 4049 ] {1641ed2b-0ce9-4ceb-8b8a-0ca436fe43d2} TCPHandler: Code: 641. DB::Exception: Cannot append data in format Parquet to file, because this format doesn't support appends. You can allow to create a new file on each insert by enabling setting engine_file_allow_create_multiple_files. (CANNOT_APPEND_TO_FILE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Storages/StorageFile.cpp:2015: DB::StorageFile::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b7b002f 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:625: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000029364754 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:28:09.391866 [ 3274 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:10.008879 [ 3907 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:10.341027 [ 3677 ] {2f3edce9-2ff2-45dc-bfe4-a6f55694998e} executeQuery: Code: 36. DB::Exception: index_granularity: value 0 makes no sense. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02514_bad_index_granularity.sql) (in query: /* ddl_entry=query-0000000019 */ CREATE TABLE test_11.t UUID 'ac966142-f8e3-4332-8a69-9f84d9ee27ab' (`id` Int64, `d` String, `p` Map(String, String)) ENGINE = ReplacingMergeTree ORDER BY id SETTINGS index_granularity = 0, min_bytes_for_wide_part = 253983722, ratio_of_defaults_for_sparse_serialization = 0.5639141798019409, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 182451026, compact_parts_max_bytes_to_buffer = 16970585, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 4584571, merge_max_block_size = 23815, old_parts_lifetime = 35., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 12588067, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 75527, primary_key_compress_block_size = 64030), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002c564d34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c862988 5. ./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) @ 0x000000002c444912 6. ./build_docker/./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>) @ 0x000000002cbc2c29 7. ./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>&&) @ 0x000000002cbc1b9a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb8258 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:10.367491 [ 3677 ] {2f3edce9-2ff2-45dc-bfe4-a6f55694998e} executeQuery: Code: 36. DB::Exception: index_granularity: value 0 makes no sense. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36962) (comment: 02514_bad_index_granularity.sql) (in query: CREATE TABLE t (`id` Int64, `d` String, `p` Map(String, String)) ENGINE = ReplacingMergeTree ORDER BY id SETTINGS index_granularity = 0, min_bytes_for_wide_part = 253983722, ratio_of_defaults_for_sparse_serialization = 0.5639141798019409, replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 182451026, compact_parts_max_bytes_to_buffer = 16970585, compact_parts_max_granules_to_buffer = 141, compact_parts_merge_max_bytes_to_prefetch_part = 4584571, merge_max_block_size = 23815, old_parts_lifetime = 35., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 12588067, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 75527, primary_key_compress_block_size = 64030), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002c564d34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c862988 5. ./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) @ 0x000000002c444912 6. ./build_docker/./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>) @ 0x000000002cbc2c29 7. ./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>&&) @ 0x000000002cbc1b9a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb8258 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:10.379711 [ 3677 ] {2f3edce9-2ff2-45dc-bfe4-a6f55694998e} TCPHandler: Code: 36. DB::Exception: index_granularity: value 0 makes no sense. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception const&>(int, FormatStringHelperImpl const&>::type>, DB::SettingFieldNumber const&) @ 0x000000002c564d34 4. ./build_docker/./src/Storages/MergeTree/MergeTreeSettings.cpp:0: DB::MergeTreeSettings::sanityCheck(unsigned long) const @ 0x000000002c862988 5. ./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) @ 0x000000002c444912 6. ./build_docker/./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>) @ 0x000000002cbc2c29 7. ./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>&&) @ 0x000000002cbc1b9a 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb8258 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 15. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 18. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 20. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:10.394342 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:10.997560 [ 4419 ] {b599a4fa-4dd1-4c77-a8ea-260ef12669d0} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:52062). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:52062) (comment: 01731_async_task_queue_wait.sh) (in query: SELECT `__table1`.`number` + sleep(0.3) AS `x` FROM `system`.`numbers` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1ad70b 6. ./build_docker/./src/Server/TCPHandler.cpp:1143: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7bf5 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:28:11.028426 [ 4419 ] {b599a4fa-4dd1-4c77-a8ea-260ef12669d0} 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]:52062). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:11.032672 [ 4419 ] {b599a4fa-4dd1-4c77-a8ea-260ef12669d0} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.2]:9000 -> [::ffff:127.0.0.1]:52062). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1ad70b 6. ./build_docker/./src/Server/TCPHandler.cpp:1143: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7bf5 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:28:11.035771 [ 4419 ] {b599a4fa-4dd1-4c77-a8ea-260ef12669d0} TCPHandler: Client has gone away. 2025.10.23 23:28:11.079838 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:11.396777 [ 2811 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:11.462981 [ 3875 ] {c96e28ea-1ae6-4215-84a2-134dc308170f} 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]:58954). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58954) (comment: 01731_async_task_queue_wait.sh) (in query: SELECT `__table1`.`number` + sleep(0.3) AS `x` FROM `system`.`numbers` AS `__table1`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1ad70b 6. ./build_docker/./src/Server/TCPHandler.cpp:1143: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7bf5 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:28:11.475561 [ 3875 ] {c96e28ea-1ae6-4215-84a2-134dc308170f} 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]:58954). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:11.478250 [ 3875 ] {c96e28ea-1ae6-4215-84a2-134dc308170f} 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]:58954). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1ad70b 6. ./build_docker/./src/Server/TCPHandler.cpp:1143: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7bf5 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:28:11.480969 [ 3875 ] {c96e28ea-1ae6-4215-84a2-134dc308170f} TCPHandler: Client has gone away. 2025.10.23 23:28:12.202501 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:12.399036 [ 2838 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:13.269127 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:13.401001 [ 2861 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:14.403272 [ 2879 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:14.496188 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:14.752711 [ 3677 ] {5f0bb792-3f33-46e8-9f4c-dc4e5f0c9ad7} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048674 bytes), maximum: 9.31 GiB: while reading column id at /var/lib/clickhouse/store/e9b/e9b98f9d-b894-4c9c-9a6d-a070504cb019/: While executing Log. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36992) (comment: 02374_analyzer_array_join.sql) (in query: SELECT id, value, value_array, value_array_element FROM test_table ARRAY JOIN value_array AS value_array_element;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000001ae00455 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adff00b 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000aa97cd0 9. ./src/Common/PODArray.h:315: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba2086 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 11. ./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>>>&) @ 0x000000002be15407 12. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x000000002be13b79 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:28:14.755645 [ 3677 ] {5f0bb792-3f33-46e8-9f4c-dc4e5f0c9ad7} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 1.00 MiB (attempt to allocate chunk of 1048674 bytes), maximum: 9.31 GiB: while reading column id at /var/lib/clickhouse/store/e9b/e9b98f9d-b894-4c9c-9a6d-a070504cb019/: While executing Log. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000001ae00455 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adff00b 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 8. void DB::PODArrayBase<8ul, 4096ul, Allocator, 63ul, 64ul>::resize<>(unsigned long) @ 0x000000000aa97cd0 9. ./src/Common/PODArray.h:315: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba2086 10. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 11. ./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>>>&) @ 0x000000002be15407 12. ./build_docker/./src/Storages/StorageLog.cpp:0: DB::LogSource::generate() @ 0x000000002be13b79 13. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 14. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 15. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 16. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 19. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:28:15.293705 [ 4419 ] {8d383fff-606e-481a-903e-7734fc0f7638} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50688) (comment: 00059_merge_sorting_empty_array_joined.sql) (in query: SELECT CounterID FROM test.visits ARRAY JOIN Goals.ID WHERE CounterID = 942285 ORDER BY CounterID ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b7f0d7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ac0b55 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:0: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df17d5a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 2025.10.23 23:28:15.327033 [ 4419 ] {8d383fff-606e-481a-903e-7734fc0f7638} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b7f0d7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ac0b55 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicasInOrder.cpp:0: DB::MergeTreeReadPoolParallelReplicasInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df17d5a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 2025.10.23 23:28:15.479648 [ 2903 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:15.567377 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:16.125999 [ 4419 ] {94b4d1eb-adce-419f-aba2-c26f96047cf2} executeQuery: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50712) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f857c3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002854616d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000029502a1b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:16.128881 [ 4419 ] {94b4d1eb-adce-419f-aba2-c26f96047cf2} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f857c3 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002854616d 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000029502a1b 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:16.482294 [ 2920 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:16.677200 [ 3907 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:17.484599 [ 2942 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:17.736442 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:18.486601 [ 2972 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:18.793791 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:18.828371 [ 4147 ] {} DynamicQueryHandler: Code: 516. DB::Exception: header_test: Authentication failed: password is incorrect, or there is no user with such name. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Access/AccessControl.cpp:626: DB::AccessControl::authenticate(DB::Credentials const&, Poco::Net::IPAddress const&, String const&) const @ 0x0000000026d31498 4. ./contrib/llvm-project/libcxx/include/string:1499: DB::Session::authenticate(DB::Credentials const&, Poco::Net::SocketAddress const&, std::vector> const&) @ 0x0000000029650812 5. ./contrib/llvm-project/libcxx/include/vector:432: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000002d1fa1a6 6. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d07cb56 7. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 8. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:19.153081 [ 4147 ] {} DynamicQueryHandler: Code: 516. DB::Exception: Got an empty user name from X-ClickHouse HTTP headers. (AUTHENTICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Server/HTTP/authenticateUserByHTTP.cpp:45: DB::authenticateUserByHTTP(DB::HTTPServerRequest const&, DB::HTMLForm const&, DB::HTTPServerResponse&, DB::Session&, std::unique_ptr>&, std::shared_ptr, std::shared_ptr) @ 0x000000002d1fb4df 5. ./build_docker/./src/Server/HTTPHandler.cpp:186: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d07cb56 6. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 7. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:19.303964 [ 2722 ] {67444fd1-9f0e-4db9-b7ca-c28f1419baf0} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01319_mv_constants_bug.sql) (in query: /* ddl_entry=query-0000000027 */ TRUNCATE TABLE IF EXISTS test_11.distributed_table_merged), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fec1c 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:28:19.340505 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:19.403536 [ 2722 ] {67444fd1-9f0e-4db9-b7ca-c28f1419baf0} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50694) (comment: 01319_mv_constants_bug.sql) (in query: DROP TABLE IF EXISTS distributed_table_merged;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fec1c 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:28:19.408224 [ 2722 ] {67444fd1-9f0e-4db9-b7ca-c28f1419baf0} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 10. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 13. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fec1c 15. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 16. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 17. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 18. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:28:19.488920 [ 3001 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:19.961749 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:19.973735 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:20.169303 [ 4203 ] {a76a1dbd-f16e-4863-aa8e-acaec039939b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50782) (comment: 00082_quantiles.sql) (in query: SELECT CounterID AS k, quantilesExact(0.1, 0.5, 0.9, 0.99, 0.999)(ResolutionWidth) FROM test.hits GROUP BY k ORDER BY count() DESC, CounterID LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:28:20.190810 [ 4203 ] {a76a1dbd-f16e-4863-aa8e-acaec039939b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:28:20.492137 [ 3024 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:20.719534 [ 3875 ] {} DynamicQueryHandler: Code: 81. DB::Exception: Database header_test does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:521: DB::DatabaseCatalog::assertDatabaseExists(String const&) const @ 0x00000000286bdee6 5. ./build_docker/./src/Interpreters/Context.cpp:2528: DB::Context::setCurrentDatabaseWithLock(String const&, std::lock_guard const&) @ 0x000000002852f5c4 6. ./src/Common/SharedMutexHelper.h:91: DB::Context::setCurrentDatabase(String const&) @ 0x000000002854722a 7. ./build_docker/./src/Server/HTTPHandler.cpp:0: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d080e00 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:21.014162 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:21.082166 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:21.116759 [ 4049 ] {999543a8-b015-49b4-ada7-a8b0dd525c65} executeQuery: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34986) (comment: 01399_http_request_headers.sh) (in query: SELECT 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x000000002d20790a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000002d20bdf6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4c2ff 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:28:21.138095 [ 4419 ] {977f9043-c06e-48dd-a257-92969f6ba325} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(nan, 3.14, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50812) (comment: 01854_s2_cap_union.sql) (in query: select s2CapUnion(nan, 3.14, 1157339245694594829, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x000000000aae4840 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000180dcbbd 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa912f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:21.151710 [ 4419 ] {977f9043-c06e-48dd-a257-92969f6ba325} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 1 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(nan, 3.14, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x000000000aae4840 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000180dcbbd 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa912f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:21.258426 [ 4049 ] {999543a8-b015-49b4-ada7-a8b0dd525c65} executeQuery: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x000000002d20790a 5. ./build_docker/./src/Formats/FormatFactory.cpp:538: DB::FormatFactory::getOutputFormat(String const&, DB::WriteBuffer&, DB::Block const&, std::shared_ptr const&, std::optional const&) const @ 0x000000002d20d3b7 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>)::$_1::operator()() const @ 0x0000000029b51577 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4dbeb 8. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 9. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 10. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:21.271751 [ 4049 ] {999543a8-b015-49b4-ada7-a8b0dd525c65} DynamicQueryHandler: Code: 73. DB::Exception: Unknown format header_test. (UNKNOWN_FORMAT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Formats/FormatFactory.cpp:46: DB::FormatFactory::getCreators(String const&) const @ 0x000000002d20790a 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:863: ? @ 0x000000002d20bdf6 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4c2ff 7. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 8. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 9. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:21.482357 [ 4419 ] {bcbf103d-0528-4ab4-a3d5-230f897f71d4} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50812) (comment: 01854_s2_cap_union.sql) (in query: select s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180dac8a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:21.487993 [ 4419 ] {bcbf103d-0528-4ab4-a3d5-230f897f71d4} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, nan, 1157339245694594829, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180dac8a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:21.501301 [ 3053 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:21.581230 [ 4419 ] {6fa33ab2-821b-46b1-9dfd-9e7528205b4a} executeQuery: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(1157339245694594829, 3.14, nan, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50812) (comment: 01854_s2_cap_union.sql) (in query: select s2CapUnion(1157339245694594829, 3.14, nan, 3.14);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x000000000aae4840 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000180dcbbd 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa912f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:21.591974 [ 4419 ] {6fa33ab2-821b-46b1-9dfd-9e7528205b4a} TCPHandler: Code: 43. DB::Exception: Illegal type Float64 of argument 3 of function s2CapUnion. Must be UInt64: In scope SELECT s2CapUnion(1157339245694594829, 3.14, nan, 3.14). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&&, String&&) @ 0x000000000aae4840 4. DB::(anonymous namespace)::FunctionS2CapUnion::getReturnTypeImpl(std::vector, std::allocator>> const&) const @ 0x00000000180dcbbd 5. DB::IFunction::getReturnTypeImpl(std::vector> const&) const @ 0x000000000aa912f3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:21.703075 [ 4419 ] {fae71dff-4d69-4176-b930-4e3132daccec} executeQuery: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50812) (comment: 01854_s2_cap_union.sql) (in query: select s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180dac8a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:21.708263 [ 4419 ] {fae71dff-4d69-4176-b930-4e3132daccec} TCPHandler: Code: 43. DB::Exception: Radius of the cap must not be nan: In scope SELECT s2CapUnion(1157339245694594829, 3.14, 1157339245694594829, nan). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. DB::(anonymous namespace)::FunctionS2CapUnion::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000180dac8a 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:22.108760 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:22.153393 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:22.504754 [ 3073 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:23.188842 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:23.222539 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:23.507659 [ 3096 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:24.248178 [ 3856 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:24.308466 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:24.510257 [ 3122 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:24.522835 [ 3121 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286d17dc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286d20a6 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:24.831288 [ 3787 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:28:30: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:25.066668 [ 2720 ] {d7481d13-d77a-4232-9a5c-5bd9ff90f79a} executeQuery: Code: 57. DB::Exception: Table test_1.local_01099_a already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:50864) (comment: 01099_parallel_distributed_insert_select.sql) (in query: CREATE TABLE local_01099_a (number UInt64) ENGINE = Log;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:25.084977 [ 2720 ] {d7481d13-d77a-4232-9a5c-5bd9ff90f79a} TCPHandler: Code: 57. DB::Exception: Table test_1.local_01099_a already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:25.291123 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:25.464841 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:25.512562 [ 3151 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:26.348902 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:26.489443 [ 4293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:26.514657 [ 3177 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:27.423086 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:27.579357 [ 3193 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:27.635907 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:28.482695 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:28.588703 [ 3218 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:28.728906 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:29.591479 [ 3242 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:29.615559 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:29.865596 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:30.497846 [ 4293 ] {e7a170b0-ab5f-487e-8fd2-3e214a0655e0} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47900) (comment: 03172_system_detached_tables.sh) (in query: DROP DATABASE test_11_lazy SYNC;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:30.512144 [ 4293 ] {e7a170b0-ab5f-487e-8fd2-3e214a0655e0} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:30.593760 [ 3261 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:30.794076 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:30.974151 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:31.595924 [ 3276 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:31.862092 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:32.139993 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:32.598086 [ 2780 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:32.816567 [ 3788 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:28:39: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:32.938602 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:33.139815 [ 3383 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1eeec400-e966-403e-a157-f2f2c437661c::202510_1_11_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:33.188135 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:33.600631 [ 2824 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:34.009172 [ 4293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:34.314040 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:34.603004 [ 2856 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:35.101310 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:35.371733 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:35.606008 [ 2883 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:36.136728 [ 4293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:36.482884 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:36.611610 [ 2908 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:37.247671 [ 4293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:37.613872 [ 2921 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:37.676270 [ 4293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:38.440661 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:38.615935 [ 2942 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:38.761429 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:39.586430 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:39.618106 [ 2962 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:39.805213 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:40.620131 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:40.620360 [ 2783 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:40.832611 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:41.187202 [ 3377 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_1_66_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:41.628385 [ 3006 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:41.648496 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:41.869665 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:42.630405 [ 3026 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:42.683507 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:42.894761 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:43.276042 [ 4049 ] {04a6f3fe-50ba-4415-baa2-3486743c05e5} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41196) (comment: 01942_dateTimeToSnowflake.sql) (in query: -- Error cases SELECT dateTimeToSnowflake();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccdc4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd6a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd75cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:28:43.309877 [ 4049 ] {04a6f3fe-50ba-4415-baa2-3486743c05e5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTimeToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccdc4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd6a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd75cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:28:43.531606 [ 4049 ] {1406e135-89ca-4dce-8b1d-12962c3c1910} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41196) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTime64ToSnowflake();), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccdc4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd6a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd75cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:28:43.537280 [ 4049 ] {1406e135-89ca-4dce-8b1d-12962c3c1910} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 0, should be 1: In scope SELECT dateTime64ToSnowflake(). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccdc4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd6a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd75cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:28:43.632619 [ 3049 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:43.742767 [ 6614 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:43.916878 [ 4049 ] {d35c5a76-0d80-4108-bbe4-a0892d941194} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41196) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTimeToSnowflake('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000aaf06f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aaeab1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae9e2a 6. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000001820ed75 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:28:43.918602 [ 4049 ] {d35c5a76-0d80-4108-bbe4-a0892d941194} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflake'. Expected: DateTime, got: String: In scope SELECT dateTimeToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000aaf06f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aaeab1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae9e2a 6. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000001820ed75 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:28:43.971601 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:44.151595 [ 4049 ] {11bbf6a2-6d00-4119-b4ab-782557060dd8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41196) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTime64ToSnowflake('abc');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000aaf06f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aaeab1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae9e2a 6. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000001820fe95 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:28:44.183986 [ 4049 ] {11bbf6a2-6d00-4119-b4ab-782557060dd8} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflake'. Expected: DateTime64, got: String: In scope SELECT dateTime64ToSnowflake('abc'). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception> const&, String, std::basic_string_view> const&, String>(int, FormatStringHelperImpl::type, std::type_identity> const&>::type, std::type_identity::type, std::type_identity> const&>::type, std::type_identity::type>, String&&, std::basic_string_view> const&, String&&, std::basic_string_view> const&, String&&) @ 0x000000000aaf06f5 4. DB::(anonymous namespace)::validateArgumentsImpl(DB::IFunction const&, std::vector> const&, unsigned long, std::vector> const&) @ 0x000000000aaeab1a 5. DB::validateFunctionArguments(DB::IFunction const&, std::vector> const&, std::vector> const&, std::vector> const&) @ 0x000000000aae9e2a 6. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::getReturnTypeImpl(std::vector> const&) const @ 0x000000001820fe95 7. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 8. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 9. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:28:44.329475 [ 4049 ] {c74445ac-1cff-4c0b-acc5-dd00a116331b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41196) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTimeToSnowflake('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccdc4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd6a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd75cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:28:44.355514 [ 4049 ] {c74445ac-1cff-4c0b-acc5-dd00a116331b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccdc4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd6a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd75cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:28:44.522088 [ 4049 ] {eb558fbc-b6a2-4776-aca6-963b407e0189} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41196) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTime64ToSnowflake('abc', 123);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccdc4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd6a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd75cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:28:44.535731 [ 4049 ] {eb558fbc-b6a2-4776-aca6-963b407e0189} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake('abc', 123). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, unsigned long&, unsigned long&) @ 0x000000000ccdc4e0 4. DB::IFunctionOverloadResolver::checkNumberOfArguments(unsigned long) const @ 0x000000000ccd6a84 5. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd75cf 6. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd7176 7. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 8. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:28:44.634812 [ 3064 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:44.832898 [ 4049 ] {bd882a78-aed8-41f8-b9ae-88d2a9f9f8f1} executeQuery: Code: 721. DB::Exception: Function dateTimeToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41196) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001820e9e1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:44.840449 [ 4049 ] {bd882a78-aed8-41f8-b9ae-88d2a9f9f8f1} TCPHandler: Code: 721. DB::Exception: Function dateTimeToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to 'true': In scope SELECT dateTimeToSnowflake(now()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. DB::(anonymous namespace)::FunctionDateTimeToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001820e9e1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:44.896884 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:45.000213 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:45.227445 [ 4049 ] {17a38c53-59d1-44e2-81e9-eec42dd17ec3} executeQuery: Code: 721. DB::Exception: Function dateTime64ToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41196) (comment: 01942_dateTimeToSnowflake.sql) (in query: SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001820fad1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:45.240250 [ 4049 ] {17a38c53-59d1-44e2-81e9-eec42dd17ec3} TCPHandler: Code: 721. DB::Exception: Function dateTime64ToSnowflake is deprecated, to enable it set setting 'allow_deprecated_snowflake_conversion_functions' to true: In scope SELECT dateTime64ToSnowflake(now64()) SETTINGS allow_deprecated_snowflake_conversion_functions = 0. (DEPRECATED_FUNCTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. DB::(anonymous namespace)::FunctionDateTime64ToSnowflake::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000001820fad1 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:28:45.637786 [ 3074 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:46.079890 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:46.177379 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:46.640300 [ 3093 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:47.127025 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:47.308898 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:47.643308 [ 3108 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:48.202525 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:48.392684 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:48.646412 [ 3132 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:49.259827 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:49.449970 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:49.648440 [ 3143 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:50.308440 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:50.496868 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:50.650348 [ 3162 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:51.409727 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:51.549780 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:51.652157 [ 3179 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:52.467383 [ 6614 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:52.611852 [ 6614 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:52.654239 [ 3197 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:53.553215 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:53.656463 [ 3209 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:53.709897 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:53.999800 [ 4147 ] {d01a2ecd-d0c4-43be-99f1-435e4c7951e0} executeQuery: Code: 57. DB::Exception: Table test_1.distributed_01099_a already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53874) (comment: 02221_parallel_replicas_bug.sh) (in query: CREATE TABLE distributed_01099_a AS local_01099_a ENGINE = Distributed('test_cluster_two_shards_localhost', currentDatabase(), local_01099_a, rand());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:54.006913 [ 4147 ] {d01a2ecd-d0c4-43be-99f1-435e4c7951e0} TCPHandler: Code: 57. DB::Exception: Table test_1.distributed_01099_a already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:28:54.207839 [ 3391 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ea299d1d-6a64-4384-9014-89925bfc5db4::202510_1_24_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:54.590697 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:54.658714 [ 3225 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:54.737918 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:55.658479 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:55.666187 [ 3243 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:55.859833 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:56.676216 [ 3271 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:56.740556 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:56.891642 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:57.678483 [ 2781 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:57.802017 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:57.930769 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:58.399367 [ 6614 ] {b970b092-ed8b-4af1-b13e-9595dfd4d502} executeQuery: Code: 1. DB::Exception: Qualified matcher arr.* found a non-compound expression [1, 2, 3] AS arr with type Array(UInt8). Expected a tuple or an array of tuples. In scope WITH [1, 2, 3] AS arr SELECT arr.*. (UNSUPPORTED_METHOD) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53328) (comment: 02677_analyzer_compound_expressions.sql) (in query: WITH [1, 2, 3] AS arr SELECT arr.*;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1744: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283990b7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b1f8b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837289a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 15. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:28:58.402697 [ 6614 ] {b970b092-ed8b-4af1-b13e-9595dfd4d502} TCPHandler: Code: 1. DB::Exception: Qualified matcher arr.* found a non-compound expression [1, 2, 3] AS arr with type Array(UInt8). Expected a tuple or an array of tuples. In scope WITH [1, 2, 3] AS arr SELECT arr.*. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1744: DB::QueryAnalyzer::resolveQualifiedMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283990b7 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveMatcher(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b1f8b 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837289a 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 15. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:28:58.685295 [ 2777 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:58.776587 [ 6614 ] {c20b71f3-6130-4f47-a08b-6eeac0b4c222} executeQuery: Code: 44. DB::Exception: The second argument of function getSubcolumn should be a constant string with the name of a subcolumn: In scope SELECT getSubcolumn([1, 2, 3], materialize('size0')). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53328) (comment: 02677_analyzer_compound_expressions.sql) (in query: SELECT getSubcolumn([1, 2, 3], materialize('size0'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000ab2e714 4. DB::(anonymous namespace)::FunctionGetSubcolumn::getSubcolumnName(std::vector> const&) @ 0x0000000010024431 5. DB::(anonymous namespace)::FunctionGetSubcolumn::getReturnTypeImpl(std::vector> const&) const @ 0x00000000100242e3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd70e2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:58.778417 [ 6614 ] {c20b71f3-6130-4f47-a08b-6eeac0b4c222} TCPHandler: Code: 44. DB::Exception: The second argument of function getSubcolumn should be a constant string with the name of a subcolumn: In scope SELECT getSubcolumn([1, 2, 3], materialize('size0')). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const* const&) @ 0x000000000ab2e714 4. DB::(anonymous namespace)::FunctionGetSubcolumn::getSubcolumnName(std::vector> const&) @ 0x0000000010024431 5. DB::(anonymous namespace)::FunctionGetSubcolumn::getReturnTypeImpl(std::vector> const&) const @ 0x00000000100242e3 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd70e2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:58.838301 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:58.950843 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:28:59.059991 [ 6614 ] {6fc96d7a-a2e6-47bd-a78f-5108d7974546} executeQuery: Code: 44. DB::Exception: There is no subcolumn aaa in type Array(UInt8): In scope SELECT getSubcolumn([1, 2, 3], 'aaa'). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53328) (comment: 02677_analyzer_compound_expressions.sql) (in query: SELECT getSubcolumn([1, 2, 3], 'aaa');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/DataTypes/IDataType.cpp:161: DB::IDataType::getSubcolumnData(std::basic_string_view>, DB::ISerialization::SubstreamData const&, bool) @ 0x0000000027a1d9fc 5. ./build_docker/./src/DataTypes/IDataType.cpp:196: DB::IDataType::getSubcolumnType(std::basic_string_view>) const @ 0x0000000027a1ecfd 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd70e2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:59.063313 [ 6614 ] {6fc96d7a-a2e6-47bd-a78f-5108d7974546} TCPHandler: Code: 44. DB::Exception: There is no subcolumn aaa in type Array(UInt8): In scope SELECT getSubcolumn([1, 2, 3], 'aaa'). (ILLEGAL_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/DataTypes/IDataType.cpp:161: DB::IDataType::getSubcolumnData(std::basic_string_view>, DB::ISerialization::SubstreamData const&, bool) @ 0x0000000027a1d9fc 5. ./build_docker/./src/DataTypes/IDataType.cpp:196: DB::IDataType::getSubcolumnType(std::basic_string_view>) const @ 0x0000000027a1ecfd 6. DB::IFunctionOverloadResolver::getReturnTypeWithoutLowCardinality(std::vector> const&) const @ 0x000000000ccd776e 7. DB::IFunctionOverloadResolver::getReturnType(std::vector> const&) const @ 0x000000000ccd70e2 8. DB::IFunctionOverloadResolver::build(std::vector> const&) const @ 0x000000000ccd8343 9. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4ab0 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:28:59.687423 [ 2816 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:28:59.992919 [ 2722 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:00.010801 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:00.689928 [ 2834 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:01.029907 [ 5127 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:01.094395 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:01.692176 [ 2843 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:02.112875 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:02.188980 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:02.694214 [ 2860 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:03.159131 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:03.244124 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:03.696253 [ 2882 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:04.218360 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:04.284930 [ 4293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:04.539095 [ 4203 ] {e9f5b878-5059-4455-b100-4188f7c249c5} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.10.23 23:29:04.579154 [ 4203 ] {e9f5b878-5059-4455-b100-4188f7c249c5} 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.10542.altinitytest (altinity build)) (from [::1]:40066) (comment: 00732_quorum_insert_lost_part_and_alive_part_zookeeper_long.sql) (in query: CREATE TABLE quorum1 (`x` UInt32, `y` Date) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_00732/quorum_lost_alive', '1') PARTITION BY y ORDER BY x SETTINGS index_granularity = 16566, min_bytes_for_wide_part = 163089364, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 96, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 40978446, compact_parts_max_granules_to_buffer = 181, compact_parts_merge_max_bytes_to_prefetch_part = 28877808, merge_max_block_size = 1860, old_parts_lifetime = 452., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 309367, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 6460408444, index_granularity_bytes = 13102686, concurrent_part_removal_threshold = 2, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 72043, primary_key_compress_block_size = 66444), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:878: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000027d65967 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d68cd6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d69a7e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:04.581673 [ 4203 ] {e9f5b878-5059-4455-b100-4188f7c249c5} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:878: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000027d65967 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d68cd6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d69a7e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:04.698443 [ 2900 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:05.270340 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:05.375588 [ 4293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:05.700802 [ 2802 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:06.242449 [ 4076 ] {eb36a0eb-eee5-4ae5-a3b4-1357c0a60d28} executeQuery: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40104) (comment: 00815_left_join_on_stepanel.sql) (in query: DROP DATABASE test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002920045c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.251855 [ 4076 ] {eb36a0eb-eee5-4ae5-a3b4-1357c0a60d28} TCPHandler: Code: 62. DB::Exception: Cannot TRUNCATE dictionary. (SYNTAX_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:262: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x000000002920045c 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.434657 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.547778 [ 4293 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.552791 [ 4076 ] {f2234074-ff11-4a11-84d5-486229b78d88} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:48944). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48944) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7db0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.565832 [ 4076 ] {f2234074-ff11-4a11-84d5-486229b78d88} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:48944). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7db0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.577117 [ 4076 ] {f2234074-ff11-4a11-84d5-486229b78d88} TCPHandler: Client has gone away. 2025.10.23 23:29:06.703298 [ 2932 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:06.888105 [ 4203 ] {7bcb474b-80ce-4002-bbd5-b093140b9db6} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:48946). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48946) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7db0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.894982 [ 4203 ] {7bcb474b-80ce-4002-bbd5-b093140b9db6} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:48946). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7db0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.897127 [ 4203 ] {7bcb474b-80ce-4002-bbd5-b093140b9db6} TCPHandler: Client has gone away. 2025.10.23 23:29:06.923103 [ 4293 ] {b735c593-b359-4b9d-a958-99cc86ff2872} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:48948). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48948) (in query: SELECT 'Hello, world'), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7db0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.932294 [ 4293 ] {b735c593-b359-4b9d-a958-99cc86ff2872} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::1]:9010 -> [::1]:48948). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a7db0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:29:06.936232 [ 4293 ] {b735c593-b359-4b9d-a958-99cc86ff2872} TCPHandler: Client has gone away. 2025.10.23 23:29:07.497196 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:07.562336 [ 6614 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:07.705480 [ 2946 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:07.782221 [ 4203 ] {881a998d-2dfb-4709-b604-ad67013ef4a4} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.10.23 23:29:07.785978 [ 4203 ] {881a998d-2dfb-4709-b604-ad67013ef4a4} 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.10542.altinitytest (altinity build)) (from [::1]:40184) (comment: 01451_replicated_detach_drop_and_quorum_long.sql) (in query: CREATE TABLE replica1 (`v` UInt8) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test/01451/quorum', 'r1') ORDER BY tuple() SETTINGS max_replicated_merges_in_queue = 0, index_granularity = 35268, min_bytes_for_wide_part = 825186309, 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 = 28208765, compact_parts_max_bytes_to_buffer = 225947867, compact_parts_max_granules_to_buffer = 37, compact_parts_merge_max_bytes_to_prefetch_part = 277768, merge_max_block_size = 16907, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 3764257475, 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 = 20674949, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 13187, primary_key_compress_block_size = 97252), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:878: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000027d65967 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d68cd6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d69a7e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:07.789689 [ 4203 ] {881a998d-2dfb-4709-b604-ad67013ef4a4} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:878: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000027d65967 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d68cd6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d69a7e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:08.423141 [ 2959 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:08.570254 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:08.618560 [ 6614 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:08.708302 [ 2960 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:09.425315 [ 2970 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:09.600758 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:09.675693 [ 6614 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:09.713957 [ 2976 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:10.427403 [ 2987 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:10.655056 [ 6614 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:10.718550 [ 2993 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:10.721689 [ 3875 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:11.429751 [ 3008 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:11.720755 [ 3016 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:11.734766 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:11.783148 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:12.432045 [ 3035 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:12.722959 [ 3038 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:12.795091 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:12.815105 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:13.021064 [ 4147 ] {1611b0c6-9d11-4b32-be37-b598cd7a567d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40172) (comment: 02365_multisearch_random_tests.sql) (in query: select [1, 0, 0, 0, 0, 1, 2, 22, 8, 17, 1, 13, 0, 0, 0, 0, 0, 5] = multiSearchAllPositions(materialize('wphcobonpgaqwgfenotzadgqezx'), ['', 'qeuycfhkfjwokxgrkaodqioaotkepzlhnrv', 'taehtytq', 'gejlcipocalc', 'poyvvvntrvqazixkwigtairjvxkgouiuva', '', 'phc', 'dg', 'npgaqwg', 'notzadgqe', '', 'wgfe', 'smipuxgvntys', 'qhrfdytbfeujzievelffzrv', 'cfmzw', 'hcywnyguzjredwjbqtwyuhtewuhzkc', 'tssfeinoykdauderpjyxtmb', 'obonpgaqwgfen']) from system.numbers limit 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:13.022609 [ 4147 ] {1611b0c6-9d11-4b32-be37-b598cd7a567d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:13.433908 [ 3046 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:13.724981 [ 3058 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:13.819950 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:13.927731 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:14.436229 [ 3070 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:14.728713 [ 3077 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:14.817584 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:14.950910 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:15.273023 [ 6610 ] {dcc82239-c611-495e-b066-84ca97333f4c} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40346) (comment: 00363_defaults.sql) (in query: SELECT * FROM prewhere_defaults PREWHERE x != 0 ORDER BY x;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:15.276355 [ 6610 ] {dcc82239-c611-495e-b066-84ca97333f4c} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=722). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:15.438775 [ 3084 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:15.730974 [ 3089 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:15.860712 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:15.995551 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:16.441092 [ 3103 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:16.719365 [ 4049 ] {269e5c2f-f9f8-4250-bc0e-c076f077e92a} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02125_fix_storage_filelog.sql) (in query: /* ddl_entry=query-0000000033 */ CREATE TABLE test_11.log UUID '1c9eeaf1-36cd-4f81-b692-6028badfe6f5' (`A` String) ENGINE = FileLog('/tmp/aaa.csv', 'CSV')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:16.733041 [ 3108 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:16.749333 [ 4049 ] {269e5c2f-f9f8-4250-bc0e-c076f077e92a} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48668) (comment: 02125_fix_storage_filelog.sql) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:16.751260 [ 4049 ] {269e5c2f-f9f8-4250-bc0e-c076f077e92a} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:16.939713 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:17.024189 [ 4049 ] {216ef5b1-d5ba-48b7-b216-8b11c5a5635f} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02125_fix_storage_filelog.sql) (in query: /* ddl_entry=query-0000000034 */ CREATE TABLE test_11.log UUID '2f898500-0976-42bd-9bb0-209f963f2975' (`A` String) ENGINE = FileLog('/tmp/aaa.csv', 'CSV')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:17.050132 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:17.066022 [ 4049 ] {216ef5b1-d5ba-48b7-b216-8b11c5a5635f} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48668) (comment: 02125_fix_storage_filelog.sql) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:17.073688 [ 4049 ] {216ef5b1-d5ba-48b7-b216-8b11c5a5635f} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:17.259004 [ 4049 ] {2d61f5df-e85e-4e9b-a8d7-03c60b2a9b3a} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 02125_fix_storage_filelog.sql) (in query: /* ddl_entry=query-0000000035 */ CREATE TABLE test_11.log UUID 'a6058a19-5adf-40f5-96f8-e3f997604136' (`A` String) ENGINE = FileLog('/tmp/aaa.csv', 'CSV')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:17.397010 [ 4049 ] {2d61f5df-e85e-4e9b-a8d7-03c60b2a9b3a} executeQuery: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48668) (comment: 02125_fix_storage_filelog.sql) (in query: CREATE TABLE log (A String) ENGINE= FileLog('/tmp/aaa.csv', 'CSV');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:17.398913 [ 4049 ] {2d61f5df-e85e-4e9b-a8d7-03c60b2a9b3a} TCPHandler: Code: 36. DB::Exception: The absolute data path should be inside `user_files_path`(/var/lib/clickhouse/user_files/). (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/FileLog/StorageFileLog.cpp:161: DB::StorageFileLog::StorageFileLog(DB::StorageID const&, std::shared_ptr, DB::ColumnsDescription const&, String const&, String const&, String const&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel) @ 0x000000002be8048d 5. ./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::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>, String const&, DB::LoadingStrictnessLevel const&, void>(std::allocator const&, DB::StorageID const&, std::shared_ptr&&, DB::ColumnsDescription const&, String&, String const&, String&, std::unique_ptr>&&, String const&, DB::LoadingStrictnessLevel const&) @ 0x000000002beace5c 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: std::shared_ptr std::__function::__policy_invoker (DB::StorageFactory::Arguments const&)>::__call_impl (DB::StorageFactory::Arguments const&)>>(std::__function::__policy_storage const*, DB::StorageFactory::Arguments const&) @ 0x000000002be98efd 7. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 15. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 16. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 18. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 19. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:17.445168 [ 3120 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:17.735419 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:17.997952 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:18.118862 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:18.302661 [ 4049 ] {63e6d4ee-11f1-421d-b77e-dfe2c6bd4521} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48692) (comment: 00042_any_left_join.sql) (in query: SELECT EventDate, hits, visits FROM ( SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate ) ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:18.322653 [ 4049 ] {63e6d4ee-11f1-421d-b77e-dfe2c6bd4521} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:18.447258 [ 3132 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:18.737938 [ 3144 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:19.088258 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:19.196729 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:19.449530 [ 3163 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:19.620091 [ 4049 ] {f7dc85df-1bd2-4714-8364-08d468ecda8d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48730) (comment: 01064_array_auc.sql) (in query: select arrayAUC(cast([10, 40, 35, 80] as Array(UInt32)), [0, 0, 1, 1]);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:19.624022 [ 4049 ] {f7dc85df-1bd2-4714-8364-08d468ecda8d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:19.740412 [ 3172 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:20.165730 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:20.209085 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:20.289946 [ 6610 ] {c7e9275d-8620-4b40-8e87-cdd46b137680} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48704) (comment: 00873_t64_codec_date.sql) (in query: SELECT * FROM t64 WHERE date16 != t_date16;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:29:20.294704 [ 6610 ] {c7e9275d-8620-4b40-8e87-cdd46b137680} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 17. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 18. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:29:20.451752 [ 3185 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:20.748058 [ 3192 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:21.212196 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:21.245726 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:21.456080 [ 3204 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:21.683513 [ 6610 ] {b4d342d7-7867-4377-a520-201c2b7b34c3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=721). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48814) (comment: 02245_s3_virtual_columns.sql) (in query: insert into test_02245 select 1 settings s3_truncate_on_insert=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d361ab7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d192da3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:29:21.689878 [ 6610 ] {b4d342d7-7867-4377-a520-201c2b7b34c3} WriteBufferFromS3: Nothing to abort. Details: bucket test, key test_02245, total size 0, count 0, hidden_size 0, offset 0, with pool: true, prefinalized false, finalized false 2025.10.23 23:29:21.720501 [ 6610 ] {b4d342d7-7867-4377-a520-201c2b7b34c3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=757, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d361ab7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d192da3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:29:21.750186 [ 3209 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:22.249779 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:22.422747 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:22.458204 [ 3222 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:22.751997 [ 3225 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:22.784956 [ 3495 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:29:27: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:23.272451 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:23.452195 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:23.465008 [ 3238 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:23.754313 [ 3248 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:23.843233 [ 6610 ] {1e2e7d08-46f6-47c0-bf57-25e4ac65ba9e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48882) (comment: 00140_rename.sql) (in query: SELECT sum(Sign) FROM test.hits WHERE CounterID = 912887;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb8392 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df07531 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:29:23.863858 [ 6610 ] {1e2e7d08-46f6-47c0-bf57-25e4ac65ba9e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb8392 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df07531 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:29:24.433264 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:24.469643 [ 3263 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:24.501112 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:24.756383 [ 3266 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:25.057863 [ 4076 ] {0024a450-4e3d-44e6-b1e2-3af27f132a97} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT CAST(EventTime, 'DateTime(\'Asia/Dubai\')') FROM test.hits ORDER BY EventTime DESC LIMIT 10. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56712) (comment: 00011_sorting.sql) (in query: SELECT EventTime::DateTime('Asia/Dubai') FROM test.hits ORDER BY EventTime DESC LIMIT 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:29:25.069135 [ 4076 ] {0024a450-4e3d-44e6-b1e2-3af27f132a97} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT CAST(EventTime, 'DateTime(\'Asia/Dubai\')') FROM test.hits ORDER BY EventTime DESC LIMIT 10. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:29:25.471669 [ 2774 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:25.532607 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:25.569064 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:25.758693 [ 3280 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:26.252151 [ 4147 ] {ad20a2e1-3209-4b0d-bf24-8b01d6ead0e7} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'PredLastVisit' in scope SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56734) (comment: 00020_distinct_order_by_distributed.sql) (in query: SELECT count() FROM (SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:29:26.269674 [ 4147 ] {ad20a2e1-3209-4b0d-bf24-8b01d6ead0e7} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'PredLastVisit' in scope SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID ASC. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:29:26.473796 [ 2785 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:26.626550 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:26.633431 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:26.760636 [ 2804 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:27.443413 [ 4203 ] {6f16519d-dcb8-4f11-b2d3-87fae8353f45} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM test.hits WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY URL, EventDate, EventDate ORDER BY URL ASC, EventDate ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56788) (comment: 00069_duplicate_aggregation_keys.sql) (in query: SELECT URL, EventDate, max(URL) FROM test.hits WHERE CounterID = 1704509 AND UserID = 4322253409885123546 GROUP BY URL, EventDate, EventDate ORDER BY URL, EventDate;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:27.457107 [ 4203 ] {6f16519d-dcb8-4f11-b2d3-87fae8353f45} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT URL, EventDate, max(URL) FROM test.hits WHERE (CounterID = 1704509) AND (UserID = 4322253409885123546) GROUP BY URL, EventDate, EventDate ORDER BY URL ASC, EventDate ASC. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:27.535305 [ 6609 ] {39566462-18c4-4d01-94da-b10649db8b24} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT BIT_AND([], []);) 2025.10.23 23:29:27.551226 [ 2816 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:27.556762 [ 6609 ] {39566462-18c4-4d01-94da-b10649db8b24} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:27.653823 [ 6609 ] {37a48bb0-d983-4e7b-ae13-723a969521c2} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT BIT_OR([], []);) 2025.10.23 23:29:27.665460 [ 6609 ] {37a48bb0-d983-4e7b-ae13-723a969521c2} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:27.676273 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:27.676664 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:27.762893 [ 2819 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:27.774344 [ 6609 ] {3b0076d6-7d2e-4479-ab50-24b1993158ef} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT BIT_XOR([], []);) 2025.10.23 23:29:27.780347 [ 6609 ] {3b0076d6-7d2e-4479-ab50-24b1993158ef} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:27.843499 [ 6609 ] {9a422f29-9473-45a4-b7bd-06313ec7199f} executeQuery: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT BLAKE3([], []);) 2025.10.23 23:29:27.852419 [ 6609 ] {9a422f29-9473-45a4-b7bd-06313ec7199f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function BLAKE3 doesn't match: passed 2, should be 1: In scope SELECT BLAKE3([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:27.961889 [ 6609 ] {21620a20-2f12-4b66-9884-90669352c7b7} executeQuery: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Array(size = 1, UInt64(size = 1), Nothing(size = 0))): In scope SELECT CAST([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT CAST([], []);) 2025.10.23 23:29:27.969091 [ 6609 ] {21620a20-2f12-4b66-9884-90669352c7b7} TCPHandler: Code: 43. DB::Exception: Second argument to CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Array(size = 1, UInt64(size = 1), Nothing(size = 0))): In scope SELECT CAST([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:28.131545 [ 6609 ] {7fdec731-f769-47cc-bd3d-087af15340b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT CHARACTER_LENGTH([], []);) 2025.10.23 23:29:28.134298 [ 6609 ] {7fdec731-f769-47cc-bd3d-087af15340b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHARACTER_LENGTH([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:28.216169 [ 6609 ] {b89ca9fe-7e08-44ab-9b67-988ec2295edd} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT CHAR_LENGTH([], []);) 2025.10.23 23:29:28.222336 [ 6609 ] {b89ca9fe-7e08-44ab-9b67-988ec2295edd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT CHAR_LENGTH([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:28.347130 [ 6609 ] {ca848f91-4c2d-417e-9abd-b8c8e36164e0} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT COVAR_POP([], []);) 2025.10.23 23:29:28.369715 [ 6609 ] {ca848f91-4c2d-417e-9abd-b8c8e36164e0} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:28.508135 [ 6609 ] {ec99ff8a-89b2-4981-a88f-7614f426e57b} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT COVAR_SAMP([], []);) 2025.10.23 23:29:28.539267 [ 6609 ] {ec99ff8a-89b2-4981-a88f-7614f426e57b} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:28.553537 [ 2836 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:28.671609 [ 6609 ] {e2e5098a-f28f-4aae-8946-3d1aade3a2fb} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT CRC32([], []);) 2025.10.23 23:29:28.683941 [ 6609 ] {e2e5098a-f28f-4aae-8946-3d1aade3a2fb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32 doesn't match: passed 2, should be 1: In scope SELECT CRC32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:28.690783 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:28.766375 [ 2837 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:28.779670 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:28.848605 [ 6609 ] {071f27b6-73ff-48d2-be5e-db6810866e81} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT CRC32IEEE([], []);) 2025.10.23 23:29:28.853757 [ 6609 ] {071f27b6-73ff-48d2-be5e-db6810866e81} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC32IEEE doesn't match: passed 2, should be 1: In scope SELECT CRC32IEEE([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:28.955055 [ 6609 ] {efd2b025-d59f-41ee-9d3f-34c1d209889e} executeQuery: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT CRC64([], []);) 2025.10.23 23:29:28.958126 [ 6609 ] {efd2b025-d59f-41ee-9d3f-34c1d209889e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function CRC64 doesn't match: passed 2, should be 1: In scope SELECT CRC64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:29.086451 [ 6609 ] {ebdf031a-8509-456d-9409-4ddd1f2255a6} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DATABASE([], []);) 2025.10.23 23:29:29.096439 [ 6609 ] {ebdf031a-8509-456d-9409-4ddd1f2255a6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT DATABASE([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:29.186173 [ 6609 ] {ed471d65-d4a0-428d-9821-7a07e891cb46} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDate'. Expected: String, got: Array(Nothing): In scope SELECT DATE([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DATE([], []);) 2025.10.23 23:29:29.201527 [ 6609 ] {ed471d65-d4a0-428d-9821-7a07e891cb46} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDate'. Expected: String, got: Array(Nothing): In scope SELECT DATE([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:29.299068 [ 6609 ] {f420eefd-2b62-4baa-9b38-acba4dadea6c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DATE_DIFF([], []);) 2025.10.23 23:29:29.306552 [ 6609 ] {f420eefd-2b62-4baa-9b38-acba4dadea6c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:29.459765 [ 6609 ] {6b44323b-9486-4ed7-a5d4-d3d8656cd921} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT DATE_FORMAT([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DATE_FORMAT([], []);) 2025.10.23 23:29:29.469155 [ 6609 ] {6b44323b-9486-4ed7-a5d4-d3d8656cd921} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT DATE_FORMAT([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:29.555513 [ 2851 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:29.723632 [ 6609 ] {064ce107-fb8d-4548-b007-0d34d0089b99} executeQuery: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT DATE_TRUNC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DATE_TRUNC([], []);) 2025.10.23 23:29:29.725191 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:29.726752 [ 6609 ] {064ce107-fb8d-4548-b007-0d34d0089b99} TCPHandler: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT DATE_TRUNC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:29.768475 [ 2853 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:29.829088 [ 2720 ] {97f278bb-234a-4c46-a6b0-c560db5ab14b} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48872) (comment: 03156_analyzer_array_join_distributed.sql) (in query: SELECT toDate(hour) AS day, `metric.names`, sum(`metric.values`) FROM remote('127.0.0.{1,2}', currentDatabase(), hourly) ARRAY JOIN metric GROUP BY day, metric.names ORDER BY metric.names;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000001ae00455 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adff00b 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000287c9152 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000287dc6dc 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000002d980f15 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x000000002d97b015 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:29.832115 [ 2720 ] {97f278bb-234a-4c46-a6b0-c560db5ab14b} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, char const*&&, String&&, long&, String&&) @ 0x000000001ae00455 4. ./build_docker/./src/Common/MemoryTracker.cpp:284: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adff00b 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::checkLimits(unsigned long, bool&) const @ 0x00000000287c9152 7. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000287dc6dc 8. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000002d980f15 9. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x000000002d97b015 10. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 11. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 14. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:29.866243 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:29.902558 [ 6609 ] {8a3e9827-bfc7-493f-9ae9-680510152648} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAY([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DAY([], []);) 2025.10.23 23:29:29.957012 [ 6609 ] {8a3e9827-bfc7-493f-9ae9-680510152648} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAY([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:29.975371 [ 4049 ] {dbc30d05-c86a-4a22-9fdf-d28dd2df668f} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika')). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56852) (comment: 00089_position_functions_with_non_constant_arg.sql) (in query: SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:29.992971 [ 4049 ] {dbc30d05-c86a-4a22-9fdf-d28dd2df668f} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika')). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:29:30.087579 [ 6609 ] {3ad4ecc6-ad6f-4f13-91f1-af20ca7d4d4c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFMONTH([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DAYOFMONTH([], []);) 2025.10.23 23:29:30.094254 [ 6609 ] {3ad4ecc6-ad6f-4f13-91f1-af20ca7d4d4c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFMONTH([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:30.164382 [ 6609 ] {3051720d-f8e2-437c-9f98-035546b9f0fa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT DAYOFWEEK([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DAYOFWEEK([], []);) 2025.10.23 23:29:30.170852 [ 6609 ] {3051720d-f8e2-437c-9f98-035546b9f0fa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT DAYOFWEEK([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:30.278331 [ 6609 ] {04b3fe85-e25e-4b9a-bd1a-007113cb6124} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFYEAR([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT DAYOFYEAR([], []);) 2025.10.23 23:29:30.291526 [ 6609 ] {04b3fe85-e25e-4b9a-bd1a-007113cb6124} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT DAYOFYEAR([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:30.436946 [ 6609 ] {36d3685d-0290-418f-b38b-266bd7155f22} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT FORMAT_BYTES([], []);) 2025.10.23 23:29:30.443380 [ 6609 ] {36d3685d-0290-418f-b38b-266bd7155f22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT FORMAT_BYTES([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:30.557675 [ 2866 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:30.686845 [ 6609 ] {e437525b-da83-419c-8c6b-fff99e7e23e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT FQDN([], []);) 2025.10.23 23:29:30.700723 [ 6609 ] {e437525b-da83-419c-8c6b-fff99e7e23e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT FQDN([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:30.770649 [ 2875 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:30.806422 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:30.812916 [ 6609 ] {ce310148-5974-4ddf-a385-c4cba9819368} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT FROM_BASE64([], []);) 2025.10.23 23:29:30.824784 [ 6609 ] {ce310148-5974-4ddf-a385-c4cba9819368} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT FROM_BASE64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:30.978455 [ 6609 ] {c8130a6f-eb4c-4c87-953b-70e309c1276e} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT FROM_DAYS([], []);) 2025.10.23 23:29:30.984153 [ 6609 ] {c8130a6f-eb4c-4c87-953b-70e309c1276e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT FROM_DAYS([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:31.024423 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:31.068713 [ 6609 ] {90af0e82-62aa-4ff2-a942-80c3014ce847} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT FROM_UNIXTIME([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT FROM_UNIXTIME([], []);) 2025.10.23 23:29:31.075894 [ 6609 ] {90af0e82-62aa-4ff2-a942-80c3014ce847} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT FROM_UNIXTIME([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:31.198960 [ 6609 ] {67fb1199-45e0-472f-931b-8804d687dca1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT HOUR([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT HOUR([], []);) 2025.10.23 23:29:31.209729 [ 6609 ] {67fb1199-45e0-472f-931b-8804d687dca1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT HOUR([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:31.300765 [ 6609 ] {8c91381f-0626-4dc3-b018-a98e59ed409b} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT INET6_ATON([], []);) 2025.10.23 23:29:31.306045 [ 6609 ] {8c91381f-0626-4dc3-b018-a98e59ed409b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET6_ATON([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:31.424239 [ 6609 ] {6e36d5b7-b467-4b00-a90c-522d4eded9b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT INET6_NTOA([], []);) 2025.10.23 23:29:31.441400 [ 6609 ] {6e36d5b7-b467-4b00-a90c-522d4eded9b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT INET6_NTOA([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:31.559883 [ 2887 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:31.561531 [ 6609 ] {a6d3af7f-999c-4020-8ae7-297e46050895} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT INET_ATON([], []);) 2025.10.23 23:29:31.631949 [ 6609 ] {a6d3af7f-999c-4020-8ae7-297e46050895} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT INET_ATON([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:31.773070 [ 2890 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:31.773871 [ 6609 ] {78918414-9a71-45f8-99c1-9a28a3ef570a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT INET_NTOA([], []);) 2025.10.23 23:29:31.780719 [ 6609 ] {78918414-9a71-45f8-99c1-9a28a3ef570a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT INET_NTOA([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:31.939344 [ 6609 ] {c98335f2-ceff-467a-889c-0d5a900b8be7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv4CIDRToRange, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4CIDRToRange([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv4CIDRToRange([], []);) 2025.10.23 23:29:31.941239 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:31.961861 [ 6609 ] {c98335f2-ceff-467a-889c-0d5a900b8be7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv4CIDRToRange, expected IPv4 or UInt8 or UInt16 or UInt32: In scope SELECT IPv4CIDRToRange([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:32.071248 [ 6609 ] {483ce1ba-68d9-4cf2-8697-badcc876855a} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv4NumToString([], []);) 2025.10.23 23:29:32.080212 [ 6609 ] {483ce1ba-68d9-4cf2-8697-badcc876855a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:32.164499 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:32.257602 [ 6609 ] {452b835e-adda-4e5f-a573-ba5acd76d5f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv4NumToStringClassC([], []);) 2025.10.23 23:29:32.260279 [ 6609 ] {452b835e-adda-4e5f-a573-ba5acd76d5f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4NumToStringClassC doesn't match: passed 2, should be 1: In scope SELECT IPv4NumToStringClassC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:32.314886 [ 6609 ] {98964537-c2b0-4f06-9d2a-c4fbe51fb2fa} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv4StringToNum([], []);) 2025.10.23 23:29:32.345978 [ 6609 ] {98964537-c2b0-4f06-9d2a-c4fbe51fb2fa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNum([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:32.498336 [ 6609 ] {234b142a-270d-4c01-8ef3-0bebb5facc76} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv4StringToNumOrDefault([], []);) 2025.10.23 23:29:32.505395 [ 6609 ] {234b142a-270d-4c01-8ef3-0bebb5facc76} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:32.569504 [ 3382 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3d81872f-1b54-4b63-aeed-f859059173ca::202510_1_46_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:32.618122 [ 6609 ] {195b5c21-74a6-47a6-9a5f-ac97b9a2aa87} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv4StringToNumOrNull([], []);) 2025.10.23 23:29:32.627945 [ 6609 ] {195b5c21-74a6-47a6-9a5f-ac97b9a2aa87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv4StringToNumOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:32.635160 [ 2902 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:32.701327 [ 6609 ] {f692cbe3-27aa-4757-9f6a-b9889096b985} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv4ToIPv6([], []);) 2025.10.23 23:29:32.708231 [ 6609 ] {f692cbe3-27aa-4757-9f6a-b9889096b985} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv4ToIPv6 doesn't match: passed 2, should be 1: In scope SELECT IPv4ToIPv6([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:32.775761 [ 2909 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:32.790076 [ 6609 ] {fc932522-05e2-4627-9a75-e7c2a58190bb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv6CIDRToRange, expected IPv6 or FixedString(16): In scope SELECT IPv6CIDRToRange([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv6CIDRToRange([], []);) 2025.10.23 23:29:32.800464 [ 6609 ] {fc932522-05e2-4627-9a75-e7c2a58190bb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function IPv6CIDRToRange, expected IPv6 or FixedString(16): In scope SELECT IPv6CIDRToRange([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:32.934682 [ 6609 ] {a7589dad-0a06-414a-87f0-9ff643200f01} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv6NumToString([], []);) 2025.10.23 23:29:32.942854 [ 6609 ] {a7589dad-0a06-414a-87f0-9ff643200f01} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6NumToString doesn't match: passed 2, should be 1: In scope SELECT IPv6NumToString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.048684 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:33.103713 [ 6609 ] {09b47bbc-4cd3-47a2-9147-f3e0ab3ba122} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv6StringToNum([], []);) 2025.10.23 23:29:33.115714 [ 6609 ] {09b47bbc-4cd3-47a2-9147-f3e0ab3ba122} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNum doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNum([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.207915 [ 6609 ] {39535fcc-9f1e-4e59-9e8a-49c0b818d12c} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv6StringToNumOrDefault([], []);) 2025.10.23 23:29:33.212883 [ 4076 ] {e02657b0-4459-4a43-902d-5a2ce85b49cd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column CounterID): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_7_7_0/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 0 with max_rows_to_read = 19547): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56896) (comment: 00151_order_by_read_in_order.sql) (in query: SELECT CounterID FROM test.hits ORDER BY CounterID LIMIT 50;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ec4c9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c819454 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c814395 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c8139cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c814b7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dec1114 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:29:33.221432 [ 6609 ] {39535fcc-9f1e-4e59-9e8a-49c0b818d12c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrDefault doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.231396 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:33.237248 [ 4076 ] {e02657b0-4459-4a43-902d-5a2ce85b49cd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column CounterID): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_7_7_0/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 0 with max_rows_to_read = 19547): While executing MergeTreeSelect(pool: ReadPoolParallelReplicasInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ec4c9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c819454 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c814395 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c8139cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c814b7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dec1114 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:29:33.294459 [ 6609 ] {25229166-fd8c-496a-9cb9-64bc87397c29} executeQuery: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT IPv6StringToNumOrNull([], []);) 2025.10.23 23:29:33.322008 [ 6609 ] {25229166-fd8c-496a-9cb9-64bc87397c29} TCPHandler: Code: 42. DB::Exception: Number of arguments for function IPv6StringToNumOrNull doesn't match: passed 2, should be 1: In scope SELECT IPv6StringToNumOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.400818 [ 6609 ] {db8a95c6-8974-40e1-9180-7a840b6b41ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONAllPaths([], []);) 2025.10.23 23:29:33.409836 [ 6609 ] {db8a95c6-8974-40e1-9180-7a840b6b41ec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPaths doesn't match: passed 2, should be 1: In scope SELECT JSONAllPaths([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.482839 [ 6609 ] {95da748a-4a50-4827-92d9-d665ee649e1d} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONAllPathsWithTypes([], []);) 2025.10.23 23:29:33.486449 [ 6609 ] {95da748a-4a50-4827-92d9-d665ee649e1d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONAllPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONAllPathsWithTypes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.557046 [ 6609 ] {8ac0528e-c832-4c4c-9a08-2d7c0fe77f15} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONArrayLength([], []);) 2025.10.23 23:29:33.563458 [ 6609 ] {8ac0528e-c832-4c4c-9a08-2d7c0fe77f15} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSONArrayLength([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.637334 [ 2918 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:33.659105 [ 6609 ] {a686d9a2-f29c-4c2c-bad9-81f28141a279} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONDynamicPaths([], []);) 2025.10.23 23:29:33.671479 [ 6609 ] {a686d9a2-f29c-4c2c-bad9-81f28141a279} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPaths doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPaths([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.777650 [ 2925 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:33.813088 [ 6609 ] {070bfd8f-ab1a-4410-a244-0f31be6de318} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONDynamicPathsWithTypes([], []);) 2025.10.23 23:29:33.834813 [ 6609 ] {070bfd8f-ab1a-4410-a244-0f31be6de318} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONDynamicPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONDynamicPathsWithTypes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:33.952887 [ 6609 ] {a67d570d-0cde-40e0-b2aa-282e3516f0cc} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: []: In scope SELECT JSONExtract([], []). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtract([], []);) 2025.10.23 23:29:33.955096 [ 6609 ] {a67d570d-0cde-40e0-b2aa-282e3516f0cc} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtract should be a constant string specifying the return data type, illegal value: []: In scope SELECT JSONExtract([], []). (ILLEGAL_COLUMN) 2025.10.23 23:29:34.056247 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:34.056853 [ 6609 ] {82c2b1a8-cb46-41d5-962f-33d629f5b321} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractArrayRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractArrayRaw([], []);) 2025.10.23 23:29:34.068375 [ 6609 ] {82c2b1a8-cb46-41d5-962f-33d629f5b321} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractArrayRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractArrayRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:34.168429 [ 6609 ] {2aad8f5d-844c-4b4c-8267-6fb1964e8e7e} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractBool([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractBool([], []);) 2025.10.23 23:29:34.177770 [ 6609 ] {2aad8f5d-844c-4b4c-8267-6fb1964e8e7e} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractBool should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractBool([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:34.228563 [ 4203 ] {b4fc4cc1-88f8-42e3-828f-0d7125b58511} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT arrayJoin([SearchEngineID]) AS search_engine, URL FROM test.hits WHERE (SearchEngineID != 0) AND (search_engine != 0). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43414) (comment: 00093_prewhere_array_join.sql) (in query: SELECT arrayJoin([SearchEngineID]) AS search_engine, URL FROM test.hits WHERE SearchEngineID != 0 AND search_engine != 0 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:34.245100 [ 4203 ] {b4fc4cc1-88f8-42e3-828f-0d7125b58511} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT arrayJoin([SearchEngineID]) AS search_engine, URL FROM test.hits WHERE (SearchEngineID != 0) AND (search_engine != 0). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:34.295984 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:34.320490 [ 6609 ] {2c40aafd-815d-44db-98ec-f7f2055a3d64} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractFloat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractFloat([], []);) 2025.10.23 23:29:34.328533 [ 6609 ] {2c40aafd-815d-44db-98ec-f7f2055a3d64} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractFloat should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractFloat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:34.438398 [ 6609 ] {8a6cd4a5-1614-4de0-a2fd-b4fa7e39513a} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractInt([], []);) 2025.10.23 23:29:34.442609 [ 6609 ] {8a6cd4a5-1614-4de0-a2fd-b4fa7e39513a} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:34.527195 [ 6609 ] {28424662-5910-4db9-b036-da974feb7cfe} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeys([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractKeys([], []);) 2025.10.23 23:29:34.531922 [ 6609 ] {28424662-5910-4db9-b036-da974feb7cfe} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeys should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeys([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:34.638646 [ 6609 ] {df45d33d-0c97-4f30-bf14-5e9ec3aad4dc} executeQuery: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: []: In scope SELECT JSONExtractKeysAndValues([], []). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractKeysAndValues([], []);) 2025.10.23 23:29:34.639863 [ 2949 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:34.647192 [ 6609 ] {df45d33d-0c97-4f30-bf14-5e9ec3aad4dc} TCPHandler: Code: 44. DB::Exception: The last argument of function JSONExtractKeysAndValues should be a constant string specifying the values' data type, illegal value: []: In scope SELECT JSONExtractKeysAndValues([], []). (ILLEGAL_COLUMN) 2025.10.23 23:29:34.779965 [ 2956 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:34.815223 [ 6609 ] {bf7f395c-fde3-4ca4-a7ac-b849e5a8eb71} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeysAndValuesRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractKeysAndValuesRaw([], []);) 2025.10.23 23:29:34.823224 [ 6609 ] {bf7f395c-fde3-4ca4-a7ac-b849e5a8eb71} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractKeysAndValuesRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractKeysAndValuesRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:35.000407 [ 6609 ] {c5050848-56c1-4e72-ab33-c8972f9b6c05} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractRaw([], []);) 2025.10.23 23:29:35.010430 [ 6609 ] {c5050848-56c1-4e72-ab33-c8972f9b6c05} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractRaw should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:35.126966 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:35.134198 [ 6609 ] {123fb4c9-9c45-492e-b344-7469352de799} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractString([], []);) 2025.10.23 23:29:35.162045 [ 6609 ] {123fb4c9-9c45-492e-b344-7469352de799} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractString should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:35.259639 [ 4076 ] {c07eb67f-b876-4d3b-9307-8fb9971943ec} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.visits. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43436) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:29:35.283003 [ 4076 ] {c07eb67f-b876-4d3b-9307-8fb9971943ec} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.visits. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:29:35.347026 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:35.368452 [ 6609 ] {030cee92-2531-4cd5-bced-abb87937974d} executeQuery: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractUInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONExtractUInt([], []);) 2025.10.23 23:29:35.417825 [ 6609 ] {030cee92-2531-4cd5-bced-abb87937974d} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONExtractUInt should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONExtractUInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:35.486768 [ 6609 ] {eb9c1a55-0d5e-4ffc-a7fc-639cf9e1c5cd} executeQuery: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONHas([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONHas([], []);) 2025.10.23 23:29:35.490790 [ 6609 ] {eb9c1a55-0d5e-4ffc-a7fc-639cf9e1c5cd} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONHas should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONHas([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:35.567776 [ 6609 ] {f9a4061f-ed74-4ebb-b140-626e25f29706} executeQuery: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONKey([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONKey([], []);) 2025.10.23 23:29:35.581012 [ 6609 ] {f9a4061f-ed74-4ebb-b140-626e25f29706} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONKey should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONKey([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:35.641976 [ 2976 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:35.782146 [ 2980 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:35.792962 [ 6609 ] {6f68d7b1-e78b-4f12-9002-ea09c2128572} executeQuery: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONLength([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONLength([], []);) 2025.10.23 23:29:35.799557 [ 6609 ] {6f68d7b1-e78b-4f12-9002-ea09c2128572} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONLength should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONLength([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:36.077558 [ 6609 ] {c0633318-fac6-4734-bb3f-6330664cdf0d} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONMergePatch([], []);) 2025.10.23 23:29:36.089139 [ 6609 ] {c0633318-fac6-4734-bb3f-6330664cdf0d} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT JSONMergePatch([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:36.169777 [ 6609 ] {0d31746f-19d3-44ed-b5d9-48d0f4cf0291} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONSharedDataPaths([], []);) 2025.10.23 23:29:36.187111 [ 6609 ] {0d31746f-19d3-44ed-b5d9-48d0f4cf0291} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPaths doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPaths([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:36.251248 [ 8267 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:36.380709 [ 6609 ] {ddfacfa6-b026-48db-a39b-a488459de5b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONSharedDataPathsWithTypes([], []);) 2025.10.23 23:29:36.387377 [ 6609 ] {ddfacfa6-b026-48db-a39b-a488459de5b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONSharedDataPathsWithTypes doesn't match: passed 2, should be 1: In scope SELECT JSONSharedDataPathsWithTypes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:36.453072 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:36.538036 [ 6609 ] {4e9ab221-a8c1-45bf-ad04-9229f8de7af7} executeQuery: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONType([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSONType([], []);) 2025.10.23 23:29:36.563877 [ 6609 ] {4e9ab221-a8c1-45bf-ad04-9229f8de7af7} TCPHandler: Code: 43. DB::Exception: The first argument of function JSONType should be a string containing JSON, illegal type: Array(Nothing): In scope SELECT JSONType([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:36.644267 [ 2994 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:36.747888 [ 6609 ] {c6eeaa73-46e0-4582-bf28-e6eab7212498} executeQuery: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSON_ARRAY_LENGTH([], []);) 2025.10.23 23:29:36.768102 [ 6609 ] {c6eeaa73-46e0-4582-bf28-e6eab7212498} TCPHandler: Code: 42. DB::Exception: Number of arguments for function JSONArrayLength doesn't match: passed 2, should be 1: In scope SELECT JSON_ARRAY_LENGTH([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:36.784347 [ 2998 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:36.909423 [ 6609 ] {125ef024-e64c-4fce-b040-8e097e3c2dec} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_EXISTS([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSON_EXISTS([], []);) 2025.10.23 23:29:36.935706 [ 6609 ] {125ef024-e64c-4fce-b040-8e097e3c2dec} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_EXISTS([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:37.037167 [ 2720 ] {0236998f-8f37-4845-b2e8-02e890b1c7c4} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43530) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.data update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:37.081403 [ 2720 ] {0236998f-8f37-4845-b2e8-02e890b1c7c4} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:37.101691 [ 8268 ] {0e365882-bcdd-4ab7-a991-4b89498f135b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43492) (comment: 00022_merge_prewhere.sql) (in query: SELECT count() FROM test.merge_hits WHERE AdvEngineID = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:29:37.118473 [ 8268 ] {0e365882-bcdd-4ab7-a991-4b89498f135b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:29:37.138722 [ 6609 ] {c664207d-8d94-437f-8f45-0b553702bec9} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_QUERY([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSON_QUERY([], []);) 2025.10.23 23:29:37.149928 [ 6609 ] {c664207d-8d94-437f-8f45-0b553702bec9} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_QUERY([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:37.298253 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:37.302547 [ 6609 ] {dca09cca-4a1c-4ca3-b9a3-e5de79a41e2c} executeQuery: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_VALUE([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT JSON_VALUE([], []);) 2025.10.23 23:29:37.316053 [ 6609 ] {dca09cca-4a1c-4ca3-b9a3-e5de79a41e2c} TCPHandler: Code: 43. DB::Exception: JSONPath functions require first argument to be JSON of string, illegal type: Array(Nothing): In scope SELECT JSON_VALUE([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:37.425180 [ 6609 ] {b6101931-87cd-454e-9a2e-08c1d7343b2b} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL1Distance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT L1Distance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT L1Distance([], []);) 2025.10.23 23:29:37.435157 [ 6609 ] {b6101931-87cd-454e-9a2e-08c1d7343b2b} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL1Distance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT L1Distance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:37.544887 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:37.549341 [ 6609 ] {76865244-4eb5-421e-a339-10fa68281468} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT L1Norm([], []);) 2025.10.23 23:29:37.561452 [ 6609 ] {76865244-4eb5-421e-a339-10fa68281468} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT L1Norm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:37.647465 [ 3018 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:37.699441 [ 6609 ] {27ba3ff7-169f-42e7-8269-4d0199d9815d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT L1Normalize([], []);) 2025.10.23 23:29:37.711510 [ 6609 ] {27ba3ff7-169f-42e7-8269-4d0199d9815d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT L1Normalize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:37.786412 [ 3024 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:37.801297 [ 6609 ] {6636b5a7-43ce-4a25-a316-276f7e7cf7a1} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL2Distance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT L2Distance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT L2Distance([], []);) 2025.10.23 23:29:37.812510 [ 6609 ] {6636b5a7-43ce-4a25-a316-276f7e7cf7a1} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL2Distance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT L2Distance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:37.986208 [ 6609 ] {420f7a4c-d7d0-4044-945f-b89e2589f94c} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT L2Norm([], []);) 2025.10.23 23:29:37.998856 [ 6609 ] {420f7a4c-d7d0-4044-945f-b89e2589f94c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT L2Norm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:38.214384 [ 6609 ] {c9d3f56c-b583-418f-8da1-28c676c346d4} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT L2Normalize([], []);) 2025.10.23 23:29:38.234704 [ 6609 ] {c9d3f56c-b583-418f-8da1-28c676c346d4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT L2Normalize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:38.341236 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:38.415492 [ 6609 ] {dab5b193-5b18-4916-a129-e4156ce8c529} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL2SquaredDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT L2SquaredDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT L2SquaredDistance([], []);) 2025.10.23 23:29:38.443278 [ 6609 ] {dab5b193-5b18-4916-a129-e4156ce8c529} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL2SquaredDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT L2SquaredDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:38.498686 [ 4076 ] {f265eba0-8bf9-4495-9046-6b5b362faf3d} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:49cb7cac-b2ce-4138-bec5-64f3cb9159ac', current host ID: '793cd66ee8bf:9000:10547f91-8d89-4c0c-b0c0-d61d31b66e4b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43630) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_13 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:38.507908 [ 4076 ] {f265eba0-8bf9-4495-9046-6b5b362faf3d} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:49cb7cac-b2ce-4138-bec5-64f3cb9159ac', current host ID: '793cd66ee8bf:9000:10547f91-8d89-4c0c-b0c0-d61d31b66e4b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:38.604767 [ 6609 ] {2d165b8e-47f5-41d8-906c-1d6ddb4ebbdf} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT L2SquaredNorm([], []);) 2025.10.23 23:29:38.615735 [ 6609 ] {2d165b8e-47f5-41d8-906c-1d6ddb4ebbdf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT L2SquaredNorm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:38.615803 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:38.649944 [ 3046 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:38.772938 [ 6609 ] {bab80b28-d282-416d-a747-894f3634a934} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT LAST_DAY([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT LAST_DAY([], []);) 2025.10.23 23:29:38.782976 [ 6609 ] {bab80b28-d282-416d-a747-894f3634a934} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT LAST_DAY([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:38.794005 [ 3053 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:38.931226 [ 4049 ] {2294390c-7fcc-432c-a9d4-c4bdb3edfa5a} executeQuery: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43686) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.local_01099_a update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:38.940667 [ 6609 ] {15c71ad9-8cb7-4724-9dcc-6d29d8671565} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLinfDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT LinfDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT LinfDistance([], []);) 2025.10.23 23:29:38.943481 [ 4049 ] {2294390c-7fcc-432c-a9d4-c4bdb3edfa5a} TCPHandler: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:38.958996 [ 6609 ] {15c71ad9-8cb7-4724-9dcc-6d29d8671565} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLinfDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT LinfDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:39.191372 [ 6609 ] {969b4ab5-dc48-45d6-87bd-ed95558453b5} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT LinfNorm([], []);) 2025.10.23 23:29:39.197092 [ 6609 ] {969b4ab5-dc48-45d6-87bd-ed95558453b5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT LinfNorm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:39.357428 [ 6609 ] {08072304-1a79-4c67-9d65-acd72386fcd3} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT LinfNormalize([], []);) 2025.10.23 23:29:39.369335 [ 6609 ] {08072304-1a79-4c67-9d65-acd72386fcd3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT LinfNormalize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:39.406132 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:39.425228 [ 8267 ] {84dadc8b-424d-4b02-9bb4-ad7f5c0d3a56} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column SearchPhrase): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_9_9_0/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 0 with max_rows_to_read = 17732): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47742) (comment: 00049_max_string_if.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, count() AS `count()`, maxIf(`__table1`.`SearchPhrase`, notEmpty(`__table1`.`SearchPhrase`)) AS `maxIf(SearchPhrase, notEmpty(SearchPhrase))` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC LIMIT _CAST(20, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769abb 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000002776e6e1 14. DB::ReadBuffer::next() @ 0x000000000b52caeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c1bd30 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c195a0 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c8162fe 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c81506d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 27. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 2025.10.23 23:29:39.445233 [ 8267 ] {84dadc8b-424d-4b02-9bb4-ad7f5c0d3a56} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column SearchPhrase): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_9_9_0/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 0 with max_rows_to_read = 17732): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769abb 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000002776e6e1 14. DB::ReadBuffer::next() @ 0x000000000b52caeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c1bd30 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c195a0 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c8162fe 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c81506d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 27. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 2025.10.23 23:29:39.517480 [ 6609 ] {034c437e-4292-46a5-98de-7fc312a61124} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT LpDistance([], []);) 2025.10.23 23:29:39.517913 [ 3654 ] {d9f40cb2-4b82-4a43-b6c4-2b8dc267eb58} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34894) (comment: 00049_max_string_if.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, count() AS `count()`, maxIf(`__table1`.`SearchPhrase`, notEmpty(`__table1`.`SearchPhrase`)) AS `maxIf(SearchPhrase, notEmpty(SearchPhrase))` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC LIMIT _CAST(20, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb8392 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df07531 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:29:39.538124 [ 6609 ] {034c437e-4292-46a5-98de-7fc312a61124} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT LpDistance([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:39.580004 [ 3654 ] {d9f40cb2-4b82-4a43-b6c4-2b8dc267eb58} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb8392 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df07531 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 27. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:29:39.606936 [ 6610 ] {69200910-d48f-4e16-b72b-39e6570673b8} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column SearchPhrase): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_9_9_0/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 0 with max_rows_to_read = 17732): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769abb 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000002776e6e1 14. DB::ReadBuffer::next() @ 0x000000000b52caeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c1bd30 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c195a0 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c8162fe 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c81506d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 27. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43638) (comment: 00049_max_string_if.sql) (in query: SELECT CounterID, count(), maxIf(SearchPhrase, notEmpty(SearchPhrase)) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cfaa85e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278b7fb6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:29:39.631751 [ 3654 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:34894, local: [::ffff:127.0.0.1]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0ba0a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0babe4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf20db6 6. DB::ReadBuffer::next() @ 0x000000000b52caeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d191773 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:39.646627 [ 6610 ] {69200910-d48f-4e16-b72b-39e6570673b8} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column SearchPhrase): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_9_9_0/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 0 with max_rows_to_read = 17732): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769abb 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:22: DB::CompressedReadBufferFromFile::nextImpl() @ 0x000000002776e6e1 14. DB::ReadBuffer::next() @ 0x000000000b52caeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:159: void DB::deserializeBinarySSE2<1>(DB::PODArray, 63ul, 64ul>&, DB::PODArray, 63ul, 64ul>&, DB::ReadBuffer&, unsigned long) @ 0x0000000027c1bd30 16. ./build_docker/./src/DataTypes/Serializations/SerializationString.cpp:259: DB::SerializationString::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027c195a0 17. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 18. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:196: DB::MergeTreeReaderWide::readData(DB::NameAndTypePair const&, std::shared_ptr const&, COW::immutable_ptr&, unsigned long, bool, unsigned long, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&, bool) @ 0x000000002c8162fe 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:158: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c81506d 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 23. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 24. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 27. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 28. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 30. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cfaa85e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278b7fb6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:29:39.658374 [ 3067 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:39.676657 [ 4419 ] {84fce4a8-cff3-4e8b-93ca-602a9f79d6b3} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:34722). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:34722) (comment: 00049_max_string_if.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, count() AS `count()`, maxIf(`__table1`.`SearchPhrase`, notEmpty(`__table1`.`SearchPhrase`)) AS `maxIf(SearchPhrase, notEmpty(SearchPhrase))` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC LIMIT _CAST(20, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d1aab0e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192ef7 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:29:39.710575 [ 4419 ] {84fce4a8-cff3-4e8b-93ca-602a9f79d6b3} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:34722). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:39.720487 [ 4419 ] {84fce4a8-cff3-4e8b-93ca-602a9f79d6b3} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.5]:9000 -> [::ffff:127.0.0.1]:34722). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendEndOfStream() @ 0x000000002d1aab0e 6. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192ef7 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:29:39.721233 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:39.722366 [ 6609 ] {b1799c53-b817-408b-965f-e01b07a553ac} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLpNorm has nested type Nothing. Support: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT LpNorm([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT LpNorm([], []);) 2025.10.23 23:29:39.732574 [ 4419 ] {84fce4a8-cff3-4e8b-93ca-602a9f79d6b3} TCPHandler: Client has gone away. 2025.10.23 23:29:39.749909 [ 6609 ] {b1799c53-b817-408b-965f-e01b07a553ac} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLpNorm has nested type Nothing. Support: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT LpNorm([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:39.796697 [ 3072 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:39.812905 [ 4049 ] {19318a75-3647-4527-8769-0394ff01e18e} executeQuery: Code: 81. DB::Exception: Database test_1_repl_01111_9 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43718) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1_repl_01111_9.rmt_11690_12491_21364 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1530: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291bbcd3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:39.815647 [ 4049 ] {19318a75-3647-4527-8769-0394ff01e18e} TCPHandler: Code: 81. DB::Exception: Database test_1_repl_01111_9 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1530: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291bbcd3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:39.869999 [ 8267 ] {84f9e2a7-790d-4777-850d-c42f07d1fc98} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:25e3edd2-7060-4628-aee4-074d13069a7c', current host ID: '793cd66ee8bf:9000:1f46cdda-f563-4cb7-b30d-e52e36ac011b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43724) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_15 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:39.895045 [ 8267 ] {84f9e2a7-790d-4777-850d-c42f07d1fc98} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:25e3edd2-7060-4628-aee4-074d13069a7c', current host ID: '793cd66ee8bf:9000:1f46cdda-f563-4cb7-b30d-e52e36ac011b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:39.914492 [ 6609 ] {9e2dbec0-54f4-422d-8909-90f9b359db93} executeQuery: Code: 43. DB::Exception: Argument 0 of function LpNorm should be tuple, got Array(Nothing): In scope SELECT LpNormalize([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT LpNormalize([], []);) 2025.10.23 23:29:39.941546 [ 6609 ] {9e2dbec0-54f4-422d-8909-90f9b359db93} TCPHandler: Code: 43. DB::Exception: Argument 0 of function LpNorm should be tuple, got Array(Nothing): In scope SELECT LpNormalize([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:40.054875 [ 6609 ] {aaa373ca-a59a-47a3-9c6c-2b0c30dfa27b} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT MACNumToString([], []);) 2025.10.23 23:29:40.078344 [ 6609 ] {aaa373ca-a59a-47a3-9c6c-2b0c30dfa27b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACNumToString doesn't match: passed 2, should be 1: In scope SELECT MACNumToString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:40.303276 [ 6609 ] {673285a9-56a2-451d-b721-9b51e07114ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT MACStringToNum([], []);) 2025.10.23 23:29:40.307021 [ 6609 ] {673285a9-56a2-451d-b721-9b51e07114ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToNum doesn't match: passed 2, should be 1: In scope SELECT MACStringToNum([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:40.457375 [ 6609 ] {b5d263bc-1a91-441a-b951-d425ff7e3f95} executeQuery: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT MACStringToOUI([], []);) 2025.10.23 23:29:40.463936 [ 8267 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:40.470070 [ 6609 ] {b5d263bc-1a91-441a-b951-d425ff7e3f95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MACStringToOUI doesn't match: passed 2, should be 1: In scope SELECT MACStringToOUI([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:40.660892 [ 3081 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:40.715959 [ 8267 ] {90ae06f9-d6ca-400a-910b-1abeae3527c0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'StartDate' in scope SELECT StartDate, if(TraficSourceID IN (0), 'type_in', 'other') AS traf_type, sum(Sign) FROM test.visits WHERE CounterID = 842440 GROUP BY StartDate, traf_type ORDER BY StartDate ASC, traf_type ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43792) (comment: 00052_group_by_in.sql) (in query: select StartDate, TraficSourceID in (0) ? 'type_in' : 'other' as traf_type, sum(Sign) from test.visits where CounterID = 842440 group by StartDate, traf_type ORDER BY StartDate, traf_type ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:40.730059 [ 8267 ] {90ae06f9-d6ca-400a-910b-1abeae3527c0} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'StartDate' in scope SELECT StartDate, if(TraficSourceID IN (0), 'type_in', 'other') AS traf_type, sum(Sign) FROM test.visits WHERE CounterID = 842440 GROUP BY StartDate, traf_type ORDER BY StartDate ASC, traf_type ASC. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:40.798799 [ 3084 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:40.866682 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:40.873875 [ 6609 ] {1bb987f2-3270-4618-b3f7-c9cc3654747f} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT MD4([], []);) 2025.10.23 23:29:40.890901 [ 6609 ] {1bb987f2-3270-4618-b3f7-c9cc3654747f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD4 doesn't match: passed 2, should be 1: In scope SELECT MD4([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:40.899079 [ 4147 ] {a8936318-a41c-4b8c-8428-a355a856c747} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43804) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:40.933202 [ 4147 ] {a8936318-a41c-4b8c-8428-a355a856c747} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:41.008948 [ 6609 ] {d09e50c0-65fd-4826-8892-fc97f68d1ae7} executeQuery: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT MD5([], []);) 2025.10.23 23:29:41.015793 [ 6609 ] {d09e50c0-65fd-4826-8892-fc97f68d1ae7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function MD5 doesn't match: passed 2, should be 1: In scope SELECT MD5([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:41.152333 [ 6609 ] {367a13af-3faa-49b2-8abb-f13f8c31c83d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MILLISECOND([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT MILLISECOND([], []);) 2025.10.23 23:29:41.172862 [ 6609 ] {367a13af-3faa-49b2-8abb-f13f8c31c83d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MILLISECOND([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:41.269777 [ 6609 ] {ccc3d83a-8047-4ab1-875d-8fa3bb431173} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MINUTE([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT MINUTE([], []);) 2025.10.23 23:29:41.289901 [ 6609 ] {ccc3d83a-8047-4ab1-875d-8fa3bb431173} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MINUTE([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:41.368853 [ 8268 ] {0bd86eb5-b7cc-4cb8-9183-941869dffb51} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43852) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_16580_6124_16580 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:41.386559 [ 8268 ] {0bd86eb5-b7cc-4cb8-9183-941869dffb51} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:41.399479 [ 4049 ] {88351597-9ee7-4451-99b0-665cd2d3232f} executeQuery: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000039 */ ALTER TABLE test_11.dist_02346 UPDATE n = n + (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) WHERE 1 SETTINGS allow_nondeterministic_mutations = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 11. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:29:41.418751 [ 6609 ] {e6fbb587-5b4d-4bc1-ab4a-ed06f0f89a9e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MONTH([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT MONTH([], []);) 2025.10.23 23:29:41.438832 [ 6609 ] {e6fbb587-5b4d-4bc1-ab4a-ed06f0f89a9e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT MONTH([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:41.462534 [ 4049 ] {88351597-9ee7-4451-99b0-665cd2d3232f} executeQuery: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43844) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.dist_02346 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 11. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:29:41.465288 [ 4049 ] {88351597-9ee7-4451-99b0-665cd2d3232f} TCPHandler: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 8. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 11. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 13. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 14. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:29:41.560878 [ 8267 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:41.649961 [ 6609 ] {67fa9965-9cfa-4efe-8326-7ba0a807746d} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT OCTET_LENGTH([], []);) 2025.10.23 23:29:41.662882 [ 3103 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:41.666725 [ 6609 ] {67fa9965-9cfa-4efe-8326-7ba0a807746d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT OCTET_LENGTH([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:41.770587 [ 6609 ] {45965d08-f49f-4126-8264-053be815df56} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT QUARTER([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT QUARTER([], []);) 2025.10.23 23:29:41.775777 [ 6609 ] {45965d08-f49f-4126-8264-053be815df56} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT QUARTER([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:41.800888 [ 3107 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:41.882878 [ 6609 ] {06d60a1f-4488-4e43-9e3d-619cd16b876b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nothing): In scope SELECT REGEXP_EXTRACT([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT REGEXP_EXTRACT([], []);) 2025.10.23 23:29:41.889428 [ 6609 ] {06d60a1f-4488-4e43-9e3d-619cd16b876b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nothing): In scope SELECT REGEXP_EXTRACT([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:41.916164 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:42.068700 [ 6609 ] {e91b3de0-8b6e-4281-9769-25c2846b5c61} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function match: In scope SELECT REGEXP_MATCHES([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT REGEXP_MATCHES([], []);) 2025.10.23 23:29:42.082000 [ 6609 ] {e91b3de0-8b6e-4281-9769-25c2846b5c61} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function match: In scope SELECT REGEXP_MATCHES([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:42.245520 [ 6609 ] {7f4659e7-adf6-45dd-8ade-0429f2700544} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT REGEXP_REPLACE([], []);) 2025.10.23 23:29:42.268307 [ 6609 ] {7f4659e7-adf6-45dd-8ade-0429f2700544} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT REGEXP_REPLACE([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:42.428683 [ 6609 ] {c958b274-3542-4042-99fa-752dd7a1e931} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SCHEMA([], []);) 2025.10.23 23:29:42.446826 [ 6609 ] {c958b274-3542-4042-99fa-752dd7a1e931} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT SCHEMA([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:42.590293 [ 6609 ] {d4e6cec6-7013-408f-b8b0-09f971da6cee} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT SECOND([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SECOND([], []);) 2025.10.23 23:29:42.593750 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:42.595876 [ 6609 ] {d4e6cec6-7013-408f-b8b0-09f971da6cee} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT SECOND([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:42.668224 [ 3122 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:42.695924 [ 4076 ] {c5c0c6a3-91bb-4a42-bda3-f011ec53ed0b} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43946) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:42.699136 [ 4076 ] {c5c0c6a3-91bb-4a42-bda3-f011ec53ed0b} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:42.738661 [ 6609 ] {6cc17521-0e12-4e85-be22-d5589765134a} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SHA1([], []);) 2025.10.23 23:29:42.749613 [ 6609 ] {6cc17521-0e12-4e85-be22-d5589765134a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA1 doesn't match: passed 2, should be 1: In scope SELECT SHA1([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:42.810070 [ 3127 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:42.917410 [ 6609 ] {3afbda7f-84a6-4528-a113-d096971af7c0} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SHA224([], []);) 2025.10.23 23:29:42.930278 [ 6609 ] {3afbda7f-84a6-4528-a113-d096971af7c0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA224 doesn't match: passed 2, should be 1: In scope SELECT SHA224([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:43.007317 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:43.113327 [ 6609 ] {8b96fe5e-0cde-4061-992b-9fad8bb6a2b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SHA256([], []);) 2025.10.23 23:29:43.130051 [ 6609 ] {8b96fe5e-0cde-4061-992b-9fad8bb6a2b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA256 doesn't match: passed 2, should be 1: In scope SELECT SHA256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:43.287691 [ 4076 ] {1259617d-f881-44dc-84be-d22301b4acda} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44012) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.data2014 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:43.294518 [ 4076 ] {1259617d-f881-44dc-84be-d22301b4acda} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:43.295726 [ 6609 ] {6e588cbb-9034-41f1-98c6-ede46951ec11} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SHA384([], []);) 2025.10.23 23:29:43.309557 [ 6609 ] {6e588cbb-9034-41f1-98c6-ede46951ec11} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA384 doesn't match: passed 2, should be 1: In scope SELECT SHA384([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:43.430542 [ 6609 ] {014a77b3-b4f4-4e32-8596-7c38193682f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SHA512([], []);) 2025.10.23 23:29:43.439010 [ 6609 ] {014a77b3-b4f4-4e32-8596-7c38193682f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512 doesn't match: passed 2, should be 1: In scope SELECT SHA512([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:43.547567 [ 6609 ] {448b09fa-d189-46f0-829a-ea84f0268be6} executeQuery: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SHA512_256([], []);) 2025.10.23 23:29:43.553297 [ 6609 ] {448b09fa-d189-46f0-829a-ea84f0268be6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function SHA512_256 doesn't match: passed 2, should be 1: In scope SELECT SHA512_256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:43.642352 [ 6610 ] {eae28bd2-4345-42d6-be75-8e2e3dc64d6c} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44040) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1.rmt_26580_10242_22888 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:43.668519 [ 6610 ] {eae28bd2-4345-42d6-be75-8e2e3dc64d6c} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:43.670206 [ 3140 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:43.683186 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:43.735986 [ 6609 ] {ea45db34-b3be-4b72-92a7-572104d32986} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT STD([], []);) 2025.10.23 23:29:43.756180 [ 6609 ] {ea45db34-b3be-4b72-92a7-572104d32986} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:43.812326 [ 3143 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:43.927171 [ 6609 ] {3f6fdeb9-e99d-4921-9147-dad708913995} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT STDDEV_POP([], []);) 2025.10.23 23:29:43.955428 [ 6609 ] {3f6fdeb9-e99d-4921-9147-dad708913995} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:44.120577 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:44.137634 [ 6609 ] {34c32d6c-d671-4b5a-b625-395af12ce74a} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT STDDEV_SAMP([], []);) 2025.10.23 23:29:44.142766 [ 6609 ] {34c32d6c-d671-4b5a-b625-395af12ce74a} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:44.284323 [ 6609 ] {bee79acb-61ba-4478-972f-ed324d767dbe} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SUBSTRING_INDEX([], []);) 2025.10.23 23:29:44.291066 [ 6609 ] {bee79acb-61ba-4478-972f-ed324d767dbe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT SUBSTRING_INDEX([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:44.417489 [ 6609 ] {4b105802-c211-4b19-8cd7-73fd193fe9e4} executeQuery: Code: 43. DB::Exception: Second argument should be String: In scope SELECT SVG([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT SVG([], []);) 2025.10.23 23:29:44.436182 [ 6609 ] {4b105802-c211-4b19-8cd7-73fd193fe9e4} TCPHandler: Code: 43. DB::Exception: Second argument should be String: In scope SELECT SVG([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:44.457952 [ 6610 ] {1a21d181-5b17-4c62-b5ca-b64e4d78c132} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:df2b12b9-f97e-4234-ab61-18155485acb2', current host ID: '793cd66ee8bf:9000:bdc988fb-f3e4-43b6-872f-53581baf4fc0'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52068) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_4 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:44.466550 [ 6610 ] {1a21d181-5b17-4c62-b5ca-b64e4d78c132} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:df2b12b9-f97e-4234-ab61-18155485acb2', current host ID: '793cd66ee8bf:9000:bdc988fb-f3e4-43b6-872f-53581baf4fc0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:44.633390 [ 6609 ] {ea2a6063-f1d5-4263-9cf6-67437ef5a724} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT TIMESTAMP_DIFF([], []);) 2025.10.23 23:29:44.652804 [ 6609 ] {ea2a6063-f1d5-4263-9cf6-67437ef5a724} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:44.674930 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:44.703297 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:44.814212 [ 6609 ] {58df8c5e-d9dc-4e2a-b874-9b43c13501d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT TO_BASE64([], []);) 2025.10.23 23:29:44.814815 [ 3162 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:44.833851 [ 6609 ] {58df8c5e-d9dc-4e2a-b874-9b43c13501d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT TO_BASE64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:45.010102 [ 6609 ] {6ceca374-670a-4a06-8298-5eb630cc610c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT TO_DAYS([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT TO_DAYS([], []);) 2025.10.23 23:29:45.042074 [ 6609 ] {6ceca374-670a-4a06-8298-5eb630cc610c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT TO_DAYS([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:45.112163 [ 6609 ] {0dc5e410-e6a9-425a-883d-fb836b61f586} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT TO_UNIXTIME([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT TO_UNIXTIME([], []);) 2025.10.23 23:29:45.179083 [ 6609 ] {0dc5e410-e6a9-425a-883d-fb836b61f586} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT TO_UNIXTIME([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:45.238922 [ 6609 ] {32c2e977-71cf-490e-b47c-2bc86a9bb17d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ULIDStringToDateTime([], []);) 2025.10.23 23:29:45.246095 [ 6609 ] {32c2e977-71cf-490e-b47c-2bc86a9bb17d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ULIDStringToDateTime. Must be String or FixedString(26).: In scope SELECT ULIDStringToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:45.314964 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:45.426335 [ 6609 ] {725ea06a-1944-46d3-8193-41d57e459189} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function URLHash: In scope SELECT URLHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT URLHash([], []);) 2025.10.23 23:29:45.433351 [ 6609 ] {725ea06a-1944-46d3-8193-41d57e459189} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function URLHash: In scope SELECT URLHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:45.643498 [ 6609 ] {2bd4d7e6-868b-4fce-89a6-dee8fd6a2a22} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT URLHierarchy([], []);) 2025.10.23 23:29:45.654396 [ 6609 ] {2bd4d7e6-868b-4fce-89a6-dee8fd6a2a22} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLHierarchy([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:45.682681 [ 3180 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:45.770195 [ 6609 ] {5f0a3f93-cf26-4084-ade8-336bbb0ddd8b} executeQuery: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT URLPathHierarchy([], []);) 2025.10.23 23:29:45.775758 [ 6609 ] {5f0a3f93-cf26-4084-ade8-336bbb0ddd8b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function URLPathHierarchy doesn't match: passed 2, should be 1: In scope SELECT URLPathHierarchy([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:45.776283 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:45.817535 [ 3184 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:45.832068 [ 6610 ] {6bf23d50-e8fe-46b6-800c-cbff7dbada34} executeQuery: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52168) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.distributed_01099_b update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:45.847511 [ 6610 ] {6bf23d50-e8fe-46b6-800c-cbff7dbada34} TCPHandler: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:45.948644 [ 4419 ] {3cf62a44-1ddd-4c03-a01f-9d5a7b761e90} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52190) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_17945_27335_29980 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:45.979513 [ 6609 ] {0c40dfee-c1ec-4383-a547-3a5329959fd1} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT UTCTimestamp([], []);) 2025.10.23 23:29:45.979536 [ 4419 ] {3cf62a44-1ddd-4c03-a01f-9d5a7b761e90} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:45.999801 [ 6609 ] {0c40dfee-c1ec-4383-a547-3a5329959fd1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTCTimestamp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:46.127001 [ 6609 ] {eb2a4af3-c474-431d-b236-e21cd911ef1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT UTC_timestamp([], []);) 2025.10.23 23:29:46.136253 [ 6609 ] {eb2a4af3-c474-431d-b236-e21cd911ef1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function UTCTimestamp doesn't match: passed 2, should be 0: In scope SELECT UTC_timestamp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:46.267400 [ 6609 ] {148f03f9-37e9-4e05-8e1f-d35d7a136ca0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function UUIDNumToString, expected FixedString(16): In scope SELECT UUIDNumToString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT UUIDNumToString([], []);) 2025.10.23 23:29:46.278068 [ 3654 ] {cf8004c8-7938-4ece-a8b0-df7d4d8e6755} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'StartURL' in scope SELECT CounterID, StartURL FROM unit, test.visits ORDER BY (CounterID, StartURL) DESC LIMIT 1000. Maybe you meant: ['ShareURL']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52204) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:46.285535 [ 6609 ] {148f03f9-37e9-4e05-8e1f-d35d7a136ca0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function UUIDNumToString, expected FixedString(16): In scope SELECT UUIDNumToString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:46.304985 [ 3654 ] {cf8004c8-7938-4ece-a8b0-df7d4d8e6755} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'StartURL' in scope SELECT CounterID, StartURL FROM unit, test.visits ORDER BY (CounterID, StartURL) DESC LIMIT 1000. Maybe you meant: ['ShareURL']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:46.424439 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:46.474462 [ 6609 ] {d7756cfe-37f5-40f2-9875-460f3fc1935c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDStringToNum, expected FixedString(36): In scope SELECT UUIDStringToNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT UUIDStringToNum([], []);) 2025.10.23 23:29:46.489313 [ 6609 ] {d7756cfe-37f5-40f2-9875-460f3fc1935c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDStringToNum, expected FixedString(36): In scope SELECT UUIDStringToNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:46.535863 [ 4049 ] {a4981889-0d56-4741-bb24-3ece7ffd3270} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:32ffb2a1-4971-420a-9cd8-c78266dc8c9e', current host ID: '793cd66ee8bf:9000:c7bbdc4f-637a-46f3-a8ab-a7c5e014ffb7'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52226) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_12 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:46.545880 [ 4049 ] {a4981889-0d56-4741-bb24-3ece7ffd3270} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:32ffb2a1-4971-420a-9cd8-c78266dc8c9e', current host ID: '793cd66ee8bf:9000:c7bbdc4f-637a-46f3-a8ab-a7c5e014ffb7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:46.684682 [ 3201 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:46.706347 [ 4076 ] {dc9ac31a-7d0d-46b1-b627-c65ecce53c70} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52890) (comment: 00181_cross_join_compression.sql) (in query: DROP DATABASE IF EXISTS test_bxnxua7y ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:29:46.708313 [ 4076 ] {dc9ac31a-7d0d-46b1-b627-c65ecce53c70} DynamicQueryHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:46.721106 [ 6609 ] {cb03651c-7a79-46d4-b69f-14c30d3bf49f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDToNum, expected UUID: In scope SELECT UUIDToNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT UUIDToNum([], []);) 2025.10.23 23:29:46.727272 [ 6609 ] {cb03651c-7a79-46d4-b69f-14c30d3bf49f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDToNum, expected UUID: In scope SELECT UUIDToNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:46.819734 [ 3200 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:46.829745 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:46.867915 [ 6609 ] {35942723-e4ed-4af5-a366-437c4428ab8c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDv7ToDateTime, expected UUID: In scope SELECT UUIDv7ToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT UUIDv7ToDateTime([], []);) 2025.10.23 23:29:46.883961 [ 6609 ] {35942723-e4ed-4af5-a366-437c4428ab8c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function UUIDv7ToDateTime, expected UUID: In scope SELECT UUIDv7ToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:47.038169 [ 6609 ] {693fa1dd-a136-48e9-8c84-0f59b4c58805} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT VAR_POP([], []);) 2025.10.23 23:29:47.068874 [ 6609 ] {693fa1dd-a136-48e9-8c84-0f59b4c58805} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:47.261214 [ 6609 ] {8c8cceff-71fc-4068-84a9-f99c4f242927} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT VAR_SAMP([], []);) 2025.10.23 23:29:47.274986 [ 6609 ] {8c8cceff-71fc-4068-84a9-f99c4f242927} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:47.449043 [ 6609 ] {c92451dd-2fe3-4c3f-b559-7a2115cdc800} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT YEAR([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT YEAR([], []);) 2025.10.23 23:29:47.458839 [ 6609 ] {c92451dd-2fe3-4c3f-b559-7a2115cdc800} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT YEAR([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:47.507191 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:47.543796 [ 6609 ] {b5f9161a-9569-497b-a6b1-bdb2be3c68f6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT YYYYMMDDToDate([], []);) 2025.10.23 23:29:47.554536 [ 6609 ] {b5f9161a-9569-497b-a6b1-bdb2be3c68f6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:47.686803 [ 3216 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:47.695663 [ 6609 ] {1c87a427-7205-417c-a959-1f5282b71355} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT YYYYMMDDToDate32([], []);) 2025.10.23 23:29:47.704597 [ 6609 ] {1c87a427-7205-417c-a959-1f5282b71355} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'YYYYMMDDToDate32'. Expected 1 argument, got 2 arguments: In scope SELECT YYYYMMDDToDate32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:47.823436 [ 3221 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:47.876968 [ 6609 ] {90598e60-09e8-4c81-8e41-dae7be884d3b} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT YYYYMMDDhhmmssToDateTime([], []);) 2025.10.23 23:29:47.910104 [ 6609 ] {90598e60-09e8-4c81-8e41-dae7be884d3b} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:47.967060 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:47.983624 [ 6609 ] {7018b041-9f73-48a6-9fde-86d90d5a1332} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT YYYYMMDDhhmmssToDateTime64([], []);) 2025.10.23 23:29:48.005983 [ 6609 ] {7018b041-9f73-48a6-9fde-86d90d5a1332} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'YYYYMMDDhhmmss' to function 'YYYYMMDDhhmmssToDateTime64'. Expected: Number, got: Array(Nothing): In scope SELECT YYYYMMDDhhmmssToDateTime64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:48.165679 [ 6609 ] {3a677fb4-a20c-4e97-a461-556c80fc3709} executeQuery: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Array(size = 1, UInt64(size = 1), Nothing(size = 0))): In scope SELECT _CAST([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT _CAST([], []);) 2025.10.23 23:29:48.173340 [ 6609 ] {3a677fb4-a20c-4e97-a461-556c80fc3709} TCPHandler: Code: 43. DB::Exception: Second argument to _CAST must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Array(size = 1, UInt64(size = 1), Nothing(size = 0))): In scope SELECT _CAST([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:48.269443 [ 6609 ] {2491949e-bf75-4c7c-ba41-86d516b01a80} executeQuery: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT __actionName([], []);) 2025.10.23 23:29:48.290335 [ 4049 ] {816b9cdd-6b52-432c-b832-97bb53255820} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000040 */ ALTER TABLE test_11.arena UPDATE n = n + (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) WHERE 1 SETTINGS allow_nondeterministic_mutations = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.291927 [ 6609 ] {2491949e-bf75-4c7c-ba41-86d516b01a80} TCPHandler: Code: 36. DB::Exception: Function __actionName is internal nad should not be used directly: In scope SELECT __actionName([], []). (BAD_ARGUMENTS) 2025.10.23 23:29:48.390693 [ 3654 ] {6d9139d0-ef53-485d-9361-bef61c708e96} executeQuery: Code: 48. DB::Exception: Method write is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52354) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: insert into test_11.distributed_table_merged values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000260ed050 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293667b0 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:794: DB::InterpreterInsertQuery::execute() @ 0x0000000029369e59 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.426849 [ 3654 ] {6d9139d0-ef53-485d-9361-bef61c708e96} TCPHandler: Code: 48. DB::Exception: Method write is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000260ed050 4. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293667b0 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:794: DB::InterpreterInsertQuery::execute() @ 0x0000000029369e59 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.442967 [ 4049 ] {816b9cdd-6b52-432c-b832-97bb53255820} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52328) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.arena update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.446403 [ 4049 ] {816b9cdd-6b52-432c-b832-97bb53255820} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 13. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 14. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 16. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 17. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.516397 [ 6609 ] {7239106b-38ec-49bd-90b6-4f33cb87ae9b} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function __bitBoolMaskAnd: In scope SELECT __bitBoolMaskAnd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT __bitBoolMaskAnd([], []);) 2025.10.23 23:29:48.527608 [ 6609 ] {7239106b-38ec-49bd-90b6-4f33cb87ae9b} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function __bitBoolMaskAnd: In scope SELECT __bitBoolMaskAnd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:48.602306 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.688849 [ 3233 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:48.686549 [ 6609 ] {a60d6920-1b3f-49d4-9144-e929f52d4c75} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function __bitBoolMaskOr: In scope SELECT __bitBoolMaskOr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT __bitBoolMaskOr([], []);) 2025.10.23 23:29:48.758389 [ 6609 ] {a60d6920-1b3f-49d4-9144-e929f52d4c75} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function __bitBoolMaskOr: In scope SELECT __bitBoolMaskOr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:48.760691 [ 8268 ] {d093e8c1-6afe-49ee-ae62-03a6f4096591} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52378) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.774394 [ 8268 ] {d093e8c1-6afe-49ee-ae62-03a6f4096591} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.777549 [ 4227 ] {749def7e-353d-4e3e-8600-4bf775e8dd24} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:29:48.800412 [ 4227 ] {749def7e-353d-4e3e-8600-4bf775e8dd24} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:48.828807 [ 3235 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:48.860052 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (1 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:48.910761 [ 6609 ] {cea3336a-1972-401e-b9c7-c365666d61b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT __bitSwapLastTwo([], []);) 2025.10.23 23:29:48.916747 [ 6609 ] {cea3336a-1972-401e-b9c7-c365666d61b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitSwapLastTwo doesn't match: passed 2, should be 1: In scope SELECT __bitSwapLastTwo([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:49.026406 [ 6609 ] {adbd0aeb-1edb-489b-a08c-18cd3f01344e} executeQuery: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT __bitWrapperFunc([], []);) 2025.10.23 23:29:49.046348 [ 6609 ] {adbd0aeb-1edb-489b-a08c-18cd3f01344e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __bitWrapperFunc doesn't match: passed 2, should be 1: In scope SELECT __bitWrapperFunc([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:49.102742 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:49.161563 [ 6609 ] {d44b273e-e097-46ed-b135-f27325e1cc63} executeQuery: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT __getScalar([], []);) 2025.10.23 23:29:49.176947 [ 6609 ] {d44b273e-e097-46ed-b135-f27325e1cc63} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __getScalar doesn't match: passed 2, should be 1: In scope SELECT __getScalar([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:49.337770 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:49.342458 [ 6609 ] {1796faad-bfa5-44f6-8fd8-9adecbd8e025} executeQuery: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT __scalarSubqueryResult([], []);) 2025.10.23 23:29:49.350996 [ 6609 ] {1796faad-bfa5-44f6-8fd8-9adecbd8e025} TCPHandler: Code: 42. DB::Exception: Number of arguments for function __scalarSubqueryResult doesn't match: passed 2, should be 1: In scope SELECT __scalarSubqueryResult([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:49.413808 [ 3495 ] {f44cc453-c1b6-4688-9ea1-489866898f87} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:29:49.423194 [ 3495 ] {f44cc453-c1b6-4688-9ea1-489866898f87} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:49.440572 [ 6609 ] {ff887724-386c-46f3-aa4b-24d58c6e4dad} executeQuery: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT abs([], []);) 2025.10.23 23:29:49.444291 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (1 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:49.449304 [ 6609 ] {ff887724-386c-46f3-aa4b-24d58c6e4dad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function abs doesn't match: passed 2, should be 1: In scope SELECT abs([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:49.661203 [ 6609 ] {e5bd98c1-7424-4b1b-a71a-28f54b7602de} executeQuery: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Array(size = 1, UInt64(size = 1), Nothing(size = 0))): In scope SELECT accurateCast([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT accurateCast([], []);) 2025.10.23 23:29:49.682606 [ 6609 ] {e5bd98c1-7424-4b1b-a71a-28f54b7602de} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCast must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Array(size = 1, UInt64(size = 1), Nothing(size = 0))): In scope SELECT accurateCast([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:49.693387 [ 3268 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:49.693816 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:49.830795 [ 3273 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:49.832583 [ 6609 ] {5ac41313-aedb-4370-a76b-3bddcfde705e} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Array(Nothing): In scope SELECT accurateCastOrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT accurateCastOrDefault([], []);) 2025.10.23 23:29:49.839210 [ 6609 ] {5ac41313-aedb-4370-a76b-3bddcfde705e} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrDefault must be a constant string describing type. Actual Array(Nothing): In scope SELECT accurateCastOrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:49.995863 [ 6609 ] {097cfa3b-54e4-46cf-a66f-b4bce7538af6} executeQuery: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Array(size = 1, UInt64(size = 1), Nothing(size = 0))): In scope SELECT accurateCastOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT accurateCastOrNull([], []);) 2025.10.23 23:29:49.999776 [ 6609 ] {097cfa3b-54e4-46cf-a66f-b4bce7538af6} TCPHandler: Code: 43. DB::Exception: Second argument to accurateCastOrNull must be a constant string describing type. Instead there is a column with the following structure: Const(size = 1, Array(size = 1, UInt64(size = 1), Nothing(size = 0))): In scope SELECT accurateCastOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:50.082665 [ 4203 ] {91c8ff33-b12c-4286-afe1-fb4f2b5ffc8d} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52470) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.google_wrappers_02266 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:50.091401 [ 4203 ] {91c8ff33-b12c-4286-afe1-fb4f2b5ffc8d} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:50.172898 [ 6609 ] {69b40c66-ac19-4b31-ba73-f7fd0225461c} executeQuery: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT acos([], []);) 2025.10.23 23:29:50.172991 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:50.205483 [ 6609 ] {69b40c66-ac19-4b31-ba73-f7fd0225461c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acos doesn't match: passed 2, should be 1: In scope SELECT acos([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:50.373097 [ 6609 ] {f4e41285-3bbe-4f02-949a-ee8894ab8501} executeQuery: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT acosh([], []);) 2025.10.23 23:29:50.390090 [ 6609 ] {f4e41285-3bbe-4f02-949a-ee8894ab8501} TCPHandler: Code: 42. DB::Exception: Number of arguments for function acosh doesn't match: passed 2, should be 1: In scope SELECT acosh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:50.573551 [ 6609 ] {3a4e0c9b-4ca7-47a2-9e1e-fc15a507fd76} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function addDate. Should be a date, a date with time or a string: In scope SELECT addDate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addDate([], []);) 2025.10.23 23:29:50.589937 [ 6609 ] {3a4e0c9b-4ca7-47a2-9e1e-fc15a507fd76} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function addDate. Should be a date, a date with time or a string: In scope SELECT addDate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:50.689928 [ 8268 ] {7cae21d4-0abd-40a4-83a7-899a7f0b4529} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52488) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format TSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:50.695577 [ 2790 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:50.700208 [ 4076 ] {85973622-f92f-4a1f-b87c-a1cda1144f26} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52508) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_1230_23078_4044 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:50.724766 [ 4076 ] {85973622-f92f-4a1f-b87c-a1cda1144f26} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:50.734647 [ 8268 ] {7cae21d4-0abd-40a4-83a7-899a7f0b4529} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:50.809641 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:50.834409 [ 2785 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:50.841556 [ 6609 ] {e61ae3fc-640c-4846-bd5d-7eff0b62a18b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addDays. Must be a date, a date with time or a String: In scope SELECT addDays([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addDays([], []);) 2025.10.23 23:29:50.872865 [ 6609 ] {e61ae3fc-640c-4846-bd5d-7eff0b62a18b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addDays. Must be a date, a date with time or a String: In scope SELECT addDays([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:50.996992 [ 6610 ] {73b8e8bf-a861-4fc5-b56c-321bea9895dd} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52526) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:51.008721 [ 6610 ] {73b8e8bf-a861-4fc5-b56c-321bea9895dd} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:51.085450 [ 6609 ] {ca0a0ef1-98fe-4baf-b408-1ad023af621e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addHours. Must be a date, a date with time or a String: In scope SELECT addHours([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addHours([], []);) 2025.10.23 23:29:51.113152 [ 6609 ] {ca0a0ef1-98fe-4baf-b408-1ad023af621e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addHours. Must be a date, a date with time or a String: In scope SELECT addHours([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:51.229101 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:51.254486 [ 6609 ] {9c8fb322-897b-45b0-b284-b4e3f3b9bffa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addInterval, must be Tuple or Interval: In scope SELECT addInterval([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addInterval([], []);) 2025.10.23 23:29:51.264476 [ 6609 ] {9c8fb322-897b-45b0-b284-b4e3f3b9bffa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addInterval, must be Tuple or Interval: In scope SELECT addInterval([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:51.457667 [ 6609 ] {3c71c358-1ae4-440b-99d1-541ac198cebd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMicroseconds. Must be a date, a date with time or a String: In scope SELECT addMicroseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addMicroseconds([], []);) 2025.10.23 23:29:51.478374 [ 6609 ] {3c71c358-1ae4-440b-99d1-541ac198cebd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMicroseconds. Must be a date, a date with time or a String: In scope SELECT addMicroseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:51.687381 [ 6609 ] {3eabaf56-7bdf-4fc5-82db-1772f857698c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMilliseconds. Must be a date, a date with time or a String: In scope SELECT addMilliseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addMilliseconds([], []);) 2025.10.23 23:29:51.694683 [ 6609 ] {3eabaf56-7bdf-4fc5-82db-1772f857698c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMilliseconds. Must be a date, a date with time or a String: In scope SELECT addMilliseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:51.697250 [ 2793 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:51.830499 [ 6609 ] {2ab6bc6d-aec9-40d1-a401-18ecb7e101dd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMinutes. Must be a date, a date with time or a String: In scope SELECT addMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addMinutes([], []);) 2025.10.23 23:29:51.836337 [ 2797 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:51.847042 [ 6609 ] {2ab6bc6d-aec9-40d1-a401-18ecb7e101dd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMinutes. Must be a date, a date with time or a String: In scope SELECT addMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:51.872090 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:51.981641 [ 4076 ] {cd035717-5595-4a09-8d63-bdbd119d65bf} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52578) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.prewhere_defaults update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:52.004822 [ 4076 ] {cd035717-5595-4a09-8d63-bdbd119d65bf} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:52.051609 [ 6609 ] {9c8477be-73b5-4595-bd73-a368c3eb5872} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMonths. Must be a date, a date with time or a String: In scope SELECT addMonths([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addMonths([], []);) 2025.10.23 23:29:52.078022 [ 6609 ] {9c8477be-73b5-4595-bd73-a368c3eb5872} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addMonths. Must be a date, a date with time or a String: In scope SELECT addMonths([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:52.192189 [ 2720 ] {3ef71bf2-35c2-4353-851d-7493f81cecb0} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:32ffb2a1-4971-420a-9cd8-c78266dc8c9e', current host ID: '793cd66ee8bf:9000:a0629d84-bb01-45b4-bbd5-debee5f02857'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52602) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_1 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:52.211517 [ 2720 ] {3ef71bf2-35c2-4353-851d-7493f81cecb0} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:32ffb2a1-4971-420a-9cd8-c78266dc8c9e', current host ID: '793cd66ee8bf:9000:a0629d84-bb01-45b4-bbd5-debee5f02857'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:52.249731 [ 6609 ] {67b9925a-409f-4e92-b02a-f9ac642d4944} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addNanoseconds. Must be a date, a date with time or a String: In scope SELECT addNanoseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addNanoseconds([], []);) 2025.10.23 23:29:52.258391 [ 6609 ] {67b9925a-409f-4e92-b02a-f9ac642d4944} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addNanoseconds. Must be a date, a date with time or a String: In scope SELECT addNanoseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:52.291219 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:52.451798 [ 6609 ] {999c3422-90b1-4342-8d64-218a32151a9d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addQuarters. Must be a date, a date with time or a String: In scope SELECT addQuarters([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addQuarters([], []);) 2025.10.23 23:29:52.484705 [ 6609 ] {999c3422-90b1-4342-8d64-218a32151a9d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addQuarters. Must be a date, a date with time or a String: In scope SELECT addQuarters([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:52.664508 [ 8268 ] {0aae97ac-e06b-49f6-b6fd-1c6a34ce3a20} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52620) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:52.690001 [ 8268 ] {0aae97ac-e06b-49f6-b6fd-1c6a34ce3a20} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:52.695025 [ 6609 ] {e3dd9eba-7318-46d0-a5f2-441202d36ee8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addSeconds. Must be a date, a date with time or a String: In scope SELECT addSeconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addSeconds([], []);) 2025.10.23 23:29:52.699376 [ 2827 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:52.719044 [ 6609 ] {e3dd9eba-7318-46d0-a5f2-441202d36ee8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addSeconds. Must be a date, a date with time or a String: In scope SELECT addSeconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:52.804482 [ 6609 ] {b714a531-bc3c-4853-a3ef-ffc68172ffcf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addTupleOfIntervals. Should be a date or a date with time: In scope SELECT addTupleOfIntervals([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addTupleOfIntervals([], []);) 2025.10.23 23:29:52.810666 [ 6609 ] {b714a531-bc3c-4853-a3ef-ffc68172ffcf} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addTupleOfIntervals. Should be a date or a date with time: In scope SELECT addTupleOfIntervals([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:52.838521 [ 2829 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:52.909194 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:52.963813 [ 6609 ] {8aebbf4c-75c6-40c4-8760-d9cd91764084} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addWeeks. Must be a date, a date with time or a String: In scope SELECT addWeeks([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addWeeks([], []);) 2025.10.23 23:29:52.981771 [ 6609 ] {8aebbf4c-75c6-40c4-8760-d9cd91764084} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addWeeks. Must be a date, a date with time or a String: In scope SELECT addWeeks([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:53.015850 [ 6610 ] {9778d95c-79f6-4ebf-a194-2c24f25a0209} executeQuery: Code: 57. DB::Exception: Table test_v52jtjrg.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52678) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:53.069998 [ 6610 ] {9778d95c-79f6-4ebf-a194-2c24f25a0209} TCPHandler: Code: 57. DB::Exception: Table test_v52jtjrg.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:53.181025 [ 6609 ] {8a83b609-9ee5-442e-aa7e-3017ace316a6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addYears. Must be a date, a date with time or a String: In scope SELECT addYears([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addYears([], []);) 2025.10.23 23:29:53.193561 [ 6609 ] {8a83b609-9ee5-442e-aa7e-3017ace316a6} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function addYears. Must be a date, a date with time or a String: In scope SELECT addYears([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:53.324753 [ 6609 ] {35759f91-ba2c-41eb-88a5-1db64a3ed31a} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addressToLine([], []);) 2025.10.23 23:29:53.338648 [ 6609 ] {35759f91-ba2c-41eb-88a5-1db64a3ed31a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLine doesn't match: passed 2, should be 1: In scope SELECT addressToLine([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:53.401318 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:53.499857 [ 6609 ] {8a87fe7c-ff45-430a-932c-b4997e4186bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addressToLineWithInlines([], []);) 2025.10.23 23:29:53.522384 [ 6609 ] {8a87fe7c-ff45-430a-932c-b4997e4186bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToLineWithInlines doesn't match: passed 2, should be 1: In scope SELECT addressToLineWithInlines([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:53.630193 [ 6609 ] {482dec51-8408-4d9b-9474-905bad83054b} executeQuery: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT addressToSymbol([], []);) 2025.10.23 23:29:53.636891 [ 6609 ] {482dec51-8408-4d9b-9474-905bad83054b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function addressToSymbol doesn't match: passed 2, should be 1: In scope SELECT addressToSymbol([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:53.664694 [ 8268 ] {f33918cd-2587-463d-aeb2-f41f8ccd0a86} executeQuery: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52706) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.distributed_01099_b update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:53.674439 [ 8268 ] {f33918cd-2587-463d-aeb2-f41f8ccd0a86} TCPHandler: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:53.701733 [ 2857 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:53.819991 [ 6609 ] {f3146cbc-7631-4afa-a072-4282ad6bcea3} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_decrypt_mysql([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT aes_decrypt_mysql([], '[HIDDEN]')) 2025.10.23 23:29:53.824720 [ 6609 ] {f3146cbc-7631-4afa-a072-4282ad6bcea3} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_decrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_decrypt_mysql([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:53.841590 [ 2861 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:53.879215 [ 2720 ] {671be6b6-3d1b-40bc-bf31-2ff631dde70e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52720) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format TSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:53.890173 [ 2720 ] {671be6b6-3d1b-40bc-bf31-2ff631dde70e} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:53.962296 [ 6609 ] {30cddde6-abb7-42fb-a2bb-928b29c95066} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_encrypt_mysql([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT aes_encrypt_mysql([], '[HIDDEN]')) 2025.10.23 23:29:53.971856 [ 6609 ] {30cddde6-abb7-42fb-a2bb-928b29c95066} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'aes_encrypt_mysql'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT aes_encrypt_mysql([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:54.005126 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:54.118278 [ 6609 ] {24d0d85c-2eb5-4484-98c0-479bce9eda32} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT age([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT age([], []);) 2025.10.23 23:29:54.125650 [ 6609 ] {24d0d85c-2eb5-4484-98c0-479bce9eda32} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'age'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT age([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:54.206705 [ 2720 ] {8133957c-150a-48d2-a193-c6c27eb96166} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:df2b12b9-f97e-4234-ab61-18155485acb2', current host ID: '793cd66ee8bf:9000:9d394059-1290-4e8f-9374-aada9024e018'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56870) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_0 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:54.218947 [ 2720 ] {8133957c-150a-48d2-a193-c6c27eb96166} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:df2b12b9-f97e-4234-ab61-18155485acb2', current host ID: '793cd66ee8bf:9000:9d394059-1290-4e8f-9374-aada9024e018'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:54.304159 [ 6609 ] {00806795-000e-4426-a714-99a693aa1555} executeQuery: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT aggThrow([], []);) 2025.10.23 23:29:54.306825 [ 6609 ] {00806795-000e-4426-a714-99a693aa1555} TCPHandler: Code: 503. DB::Exception: Aggregate function aggThrow has thrown exception successfully: While executing AggregatingTransform. (AGGREGATE_FUNCTION_THROW) 2025.10.23 23:29:54.347304 [ 4227 ] {1d45acd3-1d7b-4e4c-ae10-0561601e920f} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:29:54.352199 [ 4227 ] {1d45acd3-1d7b-4e4c-ae10-0561601e920f} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:54.363691 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (2 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:54.369183 [ 6609 ] {0daf2fc9-5662-4aac-af06-54752d2607e6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Array(Nothing): In scope SELECT alphaTokens([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT alphaTokens([], []);) 2025.10.23 23:29:54.376233 [ 6609 ] {0daf2fc9-5662-4aac-af06-54752d2607e6} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Array(Nothing): In scope SELECT alphaTokens([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:54.457483 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:54.511695 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:54.554176 [ 6609 ] {2338614e-4acd-4fe3-abb2-2e66e1c2f41e} executeQuery: Code: 36. DB::Exception: Aggregate function analysisOfVariance only supports numerical argument types. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT analysisOfVariance([], []);) 2025.10.23 23:29:54.559711 [ 6609 ] {2338614e-4acd-4fe3-abb2-2e66e1c2f41e} TCPHandler: Code: 36. DB::Exception: Aggregate function analysisOfVariance only supports numerical argument types. (BAD_ARGUMENTS) 2025.10.23 23:29:54.676267 [ 6609 ] {095c9f36-2b4d-4480-98e6-e2e0905c862f} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function and: In scope SELECT [] AND []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT and([], []);) 2025.10.23 23:29:54.685203 [ 6609 ] {095c9f36-2b4d-4480-98e6-e2e0905c862f} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function and: In scope SELECT [] AND []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:54.703533 [ 2876 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:54.843783 [ 2879 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:54.892792 [ 6609 ] {18dd40d5-484b-46c6-8025-a15c9923a290} executeQuery: Code: 36. DB::Exception: Aggregate function analysisOfVariance only supports numerical argument types. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT anova([], []);) 2025.10.23 23:29:54.895003 [ 6609 ] {18dd40d5-484b-46c6-8025-a15c9923a290} TCPHandler: Code: 36. DB::Exception: Aggregate function analysisOfVariance only supports numerical argument types. (BAD_ARGUMENTS) 2025.10.23 23:29:55.022851 [ 6609 ] {56e8e36d-645c-4c93-94c5-c65785b4d67b} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT any([], []);) 2025.10.23 23:29:55.027745 [ 6609 ] {56e8e36d-645c-4c93-94c5-c65785b4d67b} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:55.113601 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.166060 [ 6609 ] {3b9744a2-9e0d-4344-a3aa-7626d1e3e168} executeQuery: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT anyHeavy([], []);) 2025.10.23 23:29:55.181291 [ 3495 ] {f6905345-cfb7-41bc-a4d7-a2fe2a06a9ad} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.211302 [ 6609 ] {3b9744a2-9e0d-4344-a3aa-7626d1e3e168} TCPHandler: Code: 42. DB::Exception: Aggregate function anyHeavy requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:55.218336 [ 3495 ] {f6905345-cfb7-41bc-a4d7-a2fe2a06a9ad} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:55.241618 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (2 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:55.356379 [ 6609 ] {7c78939d-5d05-4ed5-abbd-0e4c39744707} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT anyLast([], []);) 2025.10.23 23:29:55.375949 [ 6609 ] {7c78939d-5d05-4ed5-abbd-0e4c39744707} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:55.408033 [ 4419 ] {47cd4745-6883-4ee9-84a5-7b9e53da60cb} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:32ffb2a1-4971-420a-9cd8-c78266dc8c9e', current host ID: '793cd66ee8bf:9000:584061fc-5b9c-48bb-90e8-7667f24a42d1'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56934) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_2 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.418349 [ 4419 ] {47cd4745-6883-4ee9-84a5-7b9e53da60cb} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:32ffb2a1-4971-420a-9cd8-c78266dc8c9e', current host ID: '793cd66ee8bf:9000:584061fc-5b9c-48bb-90e8-7667f24a42d1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.486900 [ 4049 ] {d4a84ef0-2215-4155-84d6-4c3b7570062a} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56980) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1.rmt_22914_1602_22921 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.494752 [ 4049 ] {d4a84ef0-2215-4155-84d6-4c3b7570062a} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.506118 [ 6610 ] {65a46839-994b-4539-85f3-556f22ded258} executeQuery: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_8: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56878) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1_repl_01111_8), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.545708 [ 6610 ] {65a46839-994b-4539-85f3-556f22ded258} TCPHandler: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_8: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.548925 [ 6609 ] {19f3a7e9-5e02-4218-9b4b-46c0c2894313} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT anyLast_respect_nulls([], []);) 2025.10.23 23:29:55.556502 [ 6609 ] {19f3a7e9-5e02-4218-9b4b-46c0c2894313} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:55.578009 [ 3654 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:55.705427 [ 2898 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:55.707338 [ 6609 ] {fb0a63f2-95e8-4da2-b78a-11141ae58efc} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT any_respect_nulls([], []);) 2025.10.23 23:29:55.711221 [ 6609 ] {fb0a63f2-95e8-4da2-b78a-11141ae58efc} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:55.816113 [ 4419 ] {0f676434-6a90-47e1-b3b7-89515d0c65ad} executeQuery: Code: 47. DB::Exception: Missing columns: 'n' while processing query: 'SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')', required columns: 'n': While processing (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1: While processing n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1): While processing _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1), 'Int32'): While processing if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1), 'Int32'), n): While processing _CAST(if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1), 'Int32'), n), 'Int32'). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56990) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.rmt_25754_10294_9366 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000299b56b6 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:649: 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 @ 0x0000000029395dfb 6. ./build_docker/./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) @ 0x000000002938c51e 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:212: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029386230 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:259: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000294f05b8 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000294ecbff 10. ./contrib/llvm-project/libcxx/include/vector:432: DB::getQueryInterpreter(DB::ASTSubquery const&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e655e 11. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:0: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295dec84 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295de6bd 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 16. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 17. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 20. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 21. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 22. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 23. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 24. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x00000000299bbc53 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1507: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299bebf9 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b8a22 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2162 31. ./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) @ 0x00000000295a6166 2025.10.23 23:29:55.840720 [ 6609 ] {f8bcb579-d617-445e-bb60-a99bd56e6143} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT any_value([], []);) 2025.10.23 23:29:55.840846 [ 4419 ] {0f676434-6a90-47e1-b3b7-89515d0c65ad} TCPHandler: Code: 47. DB::Exception: Missing columns: 'n' while processing query: 'SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')', required columns: 'n': While processing (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1: While processing n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1): While processing _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1), 'Int32'): While processing if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1), 'Int32'), n): While processing _CAST(if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery1), 'Int32'), n), 'Int32'). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000299b56b6 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:649: 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 @ 0x0000000029395dfb 6. ./build_docker/./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) @ 0x000000002938c51e 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:212: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029386230 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:259: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000294f05b8 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000294ecbff 10. ./contrib/llvm-project/libcxx/include/vector:432: DB::getQueryInterpreter(DB::ASTSubquery const&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e655e 11. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:0: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295dec84 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295de6bd 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 16. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 17. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 20. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 21. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 22. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 23. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 24. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x00000000299bbc53 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1507: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299bebf9 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b8a22 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2162 31. ./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) @ 0x00000000295a6166 2025.10.23 23:29:55.845808 [ 2895 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:55.850764 [ 6609 ] {f8bcb579-d617-445e-bb60-a99bd56e6143} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:55.944567 [ 6609 ] {1d37223f-6df4-448c-a807-b433bde16e73} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT any_value_respect_nulls([], []);) 2025.10.23 23:29:55.958948 [ 6609 ] {1d37223f-6df4-448c-a807-b433bde16e73} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:56.026941 [ 2720 ] {40df255d-6b81-42b0-a9c8-7f69253e1ef3} executeQuery: Code: 57. DB::Exception: Table test_v52jtjrg.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57018) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:56.047491 [ 2720 ] {40df255d-6b81-42b0-a9c8-7f69253e1ef3} TCPHandler: Code: 57. DB::Exception: Table test_v52jtjrg.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:56.182539 [ 6609 ] {3eeed360-c084-4aba-903f-a7e0591f47cc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function appendTrailingCharIfAbsent: In scope SELECT appendTrailingCharIfAbsent([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT appendTrailingCharIfAbsent([], []);) 2025.10.23 23:29:56.185184 [ 6609 ] {3eeed360-c084-4aba-903f-a7e0591f47cc} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function appendTrailingCharIfAbsent: In scope SELECT appendTrailingCharIfAbsent([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:56.305473 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:56.310306 [ 6609 ] {10e49722-a91a-4c88-9e86-274e93442747} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT approx_top_count([], []);) 2025.10.23 23:29:56.333810 [ 6609 ] {10e49722-a91a-4c88-9e86-274e93442747} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:56.516226 [ 6609 ] {e779ea4f-2fc7-47fe-aa6d-9a1dd6fac023} executeQuery: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT approx_top_k([], []);) 2025.10.23 23:29:56.544072 [ 6609 ] {e779ea4f-2fc7-47fe-aa6d-9a1dd6fac023} TCPHandler: Code: 42. DB::Exception: Aggregate function approx_top_k requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:56.621650 [ 6609 ] {33351a3b-f5ce-41a2-9835-cc25ba4a6ba6} executeQuery: Code: 43. DB::Exception: The second argument for aggregate function 'topKWeighted' must have integer type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT approx_top_sum([], []);) 2025.10.23 23:29:56.621759 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:56.641974 [ 6609 ] {33351a3b-f5ce-41a2-9835-cc25ba4a6ba6} TCPHandler: Code: 43. DB::Exception: The second argument for aggregate function 'topKWeighted' must have integer type. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:56.711670 [ 2919 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:56.737488 [ 4419 ] {f5728d84-3323-45f9-8465-51e08f9fade6} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57064) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:56.739312 [ 6609 ] {13eff387-58e5-4647-b946-8cff4aff3b7a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of aggregate function argMax because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT argMax([], []);) 2025.10.23 23:29:56.743013 [ 4419 ] {f5728d84-3323-45f9-8465-51e08f9fade6} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:56.744240 [ 6609 ] {13eff387-58e5-4647-b946-8cff4aff3b7a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of aggregate function argMax because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:56.847884 [ 2918 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:56.898441 [ 6609 ] {4e54482f-260a-415c-b40c-f30395311655} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of aggregate function argMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT argMin([], []);) 2025.10.23 23:29:56.912433 [ 6609 ] {4e54482f-260a-415c-b40c-f30395311655} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of second argument of aggregate function argMin because the values of that data type are not comparable. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:57.237440 [ 6609 ] {99eb6a40-b5b7-407c-a77d-071309d71442} executeQuery: Code: 43. DB::Exception: arrayAUC cannot process values of type Nothing: In scope SELECT arrayAUC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayAUC([], []);) 2025.10.23 23:29:57.258370 [ 6609 ] {99eb6a40-b5b7-407c-a77d-071309d71442} TCPHandler: Code: 43. DB::Exception: arrayAUC cannot process values of type Nothing: In scope SELECT arrayAUC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:57.356850 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:57.383687 [ 6609 ] {5eb69e37-584f-4cb3-8272-0f265d1c0d3d} executeQuery: Code: 43. DB::Exception: First argument for function arrayAll must be a function. Actual Array(Nothing): In scope SELECT arrayAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayAll([], []);) 2025.10.23 23:29:57.396615 [ 6609 ] {5eb69e37-584f-4cb3-8272-0f265d1c0d3d} TCPHandler: Code: 43. DB::Exception: First argument for function arrayAll must be a function. Actual Array(Nothing): In scope SELECT arrayAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:57.513498 [ 6609 ] {97657e75-0bcb-46d8-a21b-e70d609056c6} executeQuery: Code: 43. DB::Exception: First argument for function arrayAvg must be a function. Actual Array(Nothing): In scope SELECT arrayAvg([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayAvg([], []);) 2025.10.23 23:29:57.518360 [ 6609 ] {97657e75-0bcb-46d8-a21b-e70d609056c6} TCPHandler: Code: 43. DB::Exception: First argument for function arrayAvg must be a function. Actual Array(Nothing): In scope SELECT arrayAvg([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:57.600315 [ 6609 ] {53112f9d-c0f7-4a3a-acb8-682d69334a28} executeQuery: Code: 43. DB::Exception: First argument for function arrayCompact must be a function. Actual Array(Nothing): In scope SELECT arrayCompact([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayCompact([], []);) 2025.10.23 23:29:57.654622 [ 6609 ] {53112f9d-c0f7-4a3a-acb8-682d69334a28} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCompact must be a function. Actual Array(Nothing): In scope SELECT arrayCompact([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:57.702908 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:57.713552 [ 2943 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:57.798107 [ 3527 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:30:03: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:57.850503 [ 2951 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:57.954074 [ 6609 ] {4317befd-f702-4e62-a33d-eae4f2b7d354} executeQuery: Code: 43. DB::Exception: First argument for function arrayCount must be a function. Actual Array(Nothing): In scope SELECT arrayCount([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayCount([], []);) 2025.10.23 23:29:57.959323 [ 6609 ] {4317befd-f702-4e62-a33d-eae4f2b7d354} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCount must be a function. Actual Array(Nothing): In scope SELECT arrayCount([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:58.060652 [ 6609 ] {cbf77e63-3866-4bde-ab3f-4439408cf0c0} executeQuery: Code: 43. DB::Exception: First argument for function arrayCumSum must be a function. Actual Array(Nothing): In scope SELECT arrayCumSum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayCumSum([], []);) 2025.10.23 23:29:58.068309 [ 6609 ] {cbf77e63-3866-4bde-ab3f-4439408cf0c0} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCumSum must be a function. Actual Array(Nothing): In scope SELECT arrayCumSum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:58.167496 [ 6609 ] {2b439b96-bdf6-49ab-b0b1-b3cc3365a77e} executeQuery: Code: 43. DB::Exception: First argument for function arrayCumSumNonNegative must be a function. Actual Array(Nothing): In scope SELECT arrayCumSumNonNegative([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayCumSumNonNegative([], []);) 2025.10.23 23:29:58.183159 [ 6609 ] {2b439b96-bdf6-49ab-b0b1-b3cc3365a77e} TCPHandler: Code: 43. DB::Exception: First argument for function arrayCumSumNonNegative must be a function. Actual Array(Nothing): In scope SELECT arrayCumSumNonNegative([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:58.258221 [ 6609 ] {b294dd31-3f46-4f5d-a63f-22a50a63e118} executeQuery: Code: 43. DB::Exception: First argument for function arrayDifference must be a function. Actual Array(Nothing): In scope SELECT arrayDifference([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayDifference([], []);) 2025.10.23 23:29:58.266186 [ 6609 ] {b294dd31-3f46-4f5d-a63f-22a50a63e118} TCPHandler: Code: 43. DB::Exception: First argument for function arrayDifference must be a function. Actual Array(Nothing): In scope SELECT arrayDifference([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:58.381038 [ 6609 ] {f9dfe40c-3c1b-4f54-8bb6-4ce4157a9e10} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayDistinct([], []);) 2025.10.23 23:29:58.389940 [ 6609 ] {f9dfe40c-3c1b-4f54-8bb6-4ce4157a9e10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayDistinct doesn't match: passed 2, should be 1: In scope SELECT arrayDistinct([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:58.419476 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:58.586325 [ 6609 ] {9e853fee-0d7a-4102-beb6-62fb1c32eab0} executeQuery: Code: 43. DB::Exception: Function arrayDotProduct cannot process values of type Nothing: In scope SELECT arrayDotProduct([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayDotProduct([], []);) 2025.10.23 23:29:58.597849 [ 6609 ] {9e853fee-0d7a-4102-beb6-62fb1c32eab0} TCPHandler: Code: 43. DB::Exception: Function arrayDotProduct cannot process values of type Nothing: In scope SELECT arrayDotProduct([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:58.715918 [ 2966 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:58.738616 [ 6609 ] {fad32631-6fa2-4963-a70c-efa65000915c} executeQuery: Code: 43. DB::Exception: Second argument for function 'arrayElement' must be integer, got 'Array(Nothing)' instead: In scope SELECT [][[]]. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayElement([], []);) 2025.10.23 23:29:58.750619 [ 6609 ] {fad32631-6fa2-4963-a70c-efa65000915c} TCPHandler: Code: 43. DB::Exception: Second argument for function 'arrayElement' must be integer, got 'Array(Nothing)' instead: In scope SELECT [][[]]. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:58.786885 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:58.846098 [ 6609 ] {5cdfa40c-bc71-475c-b797-089a0f54512d} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayEnumerate([], []);) 2025.10.23 23:29:58.850898 [ 6609 ] {5cdfa40c-bc71-475c-b797-089a0f54512d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayEnumerate doesn't match: passed 2, should be 1: In scope SELECT arrayEnumerate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:29:58.852582 [ 2973 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:59.011840 [ 2720 ] {4a0c8428-0caa-4a1d-ab60-501e845464b3} executeQuery: Code: 57. DB::Exception: Table test_v52jtjrg.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57112) (comment: 00161_parallel_parsing_with_names.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:59.020690 [ 2720 ] {4a0c8428-0caa-4a1d-ab60-501e845464b3} TCPHandler: Code: 57. DB::Exception: Table test_v52jtjrg.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:29:59.466577 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:59.688301 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:59.693085 [ 6609 ] {e30feb15-2098-4fae-a17b-6794104a607e} executeQuery: Code: 43. DB::Exception: First argument for function arrayExists must be a function. Actual Array(Nothing): In scope SELECT arrayExists([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayExists([], []);) 2025.10.23 23:29:59.707409 [ 6609 ] {e30feb15-2098-4fae-a17b-6794104a607e} TCPHandler: Code: 43. DB::Exception: First argument for function arrayExists must be a function. Actual Array(Nothing): In scope SELECT arrayExists([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:59.718091 [ 2988 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:59.794679 [ 6610 ] {b62f603e-d7bf-47b1-9437-87abdade4396} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57142) (comment: 00161_parallel_parsing_with_names.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 50000 Format CSVWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:59.800187 [ 6610 ] {b62f603e-d7bf-47b1-9437-87abdade4396} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 50000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:29:59.848373 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:29:59.856292 [ 2990 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:29:59.856473 [ 6609 ] {7a6a3b2d-f644-43cd-b1dd-5ea6de4fca05} executeQuery: Code: 43. DB::Exception: First argument for function arrayFill must be a function. Actual Array(Nothing): In scope SELECT arrayFill([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayFill([], []);) 2025.10.23 23:29:59.864498 [ 6609 ] {7a6a3b2d-f644-43cd-b1dd-5ea6de4fca05} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFill must be a function. Actual Array(Nothing): In scope SELECT arrayFill([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:29:59.976505 [ 6609 ] {a6da0b76-b5d8-4dee-af69-7f698839f6ef} executeQuery: Code: 43. DB::Exception: First argument for function arrayFilter must be a function. Actual Array(Nothing): In scope SELECT arrayFilter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayFilter([], []);) 2025.10.23 23:29:59.981846 [ 6609 ] {a6da0b76-b5d8-4dee-af69-7f698839f6ef} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFilter must be a function. Actual Array(Nothing): In scope SELECT arrayFilter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:00.214661 [ 6609 ] {beee8719-fd9d-4394-94c8-616d225e35e0} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirst must be a function. Actual Array(Nothing): In scope SELECT arrayFirst([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayFirst([], []);) 2025.10.23 23:30:00.226736 [ 6609 ] {beee8719-fd9d-4394-94c8-616d225e35e0} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirst must be a function. Actual Array(Nothing): In scope SELECT arrayFirst([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:00.285974 [ 4227 ] {0ce87367-e92a-46a0-b638-b40a4003a676} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:00.287863 [ 4227 ] {0ce87367-e92a-46a0-b638-b40a4003a676} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:00.364764 [ 6609 ] {69878bb0-6c56-4ba2-99cf-7348e5234ba2} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirstIndex must be a function. Actual Array(Nothing): In scope SELECT arrayFirstIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayFirstIndex([], []);) 2025.10.23 23:30:00.371097 [ 6609 ] {69878bb0-6c56-4ba2-99cf-7348e5234ba2} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirstIndex must be a function. Actual Array(Nothing): In scope SELECT arrayFirstIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:00.372887 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (3 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:00.447110 [ 6609 ] {70150428-bcab-453c-b384-8e33d9bd5413} executeQuery: Code: 43. DB::Exception: First argument for function arrayFirstOrNull must be a function. Actual Array(Nothing): In scope SELECT arrayFirstOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayFirstOrNull([], []);) 2025.10.23 23:30:00.452543 [ 6609 ] {70150428-bcab-453c-b384-8e33d9bd5413} TCPHandler: Code: 43. DB::Exception: First argument for function arrayFirstOrNull must be a function. Actual Array(Nothing): In scope SELECT arrayFirstOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:00.497908 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:00.523141 [ 6609 ] {5660544a-3f94-4f34-9567-3b833c255e61} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayFlatten([], []);) 2025.10.23 23:30:00.537920 [ 6609 ] {5660544a-3f94-4f34-9567-3b833c255e61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT arrayFlatten([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:00.684691 [ 6609 ] {48e7378a-56e3-48ac-9b3c-04c0400a4325} executeQuery: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold([], []). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayFold([], []);) 2025.10.23 23:30:00.693955 [ 6609 ] {48e7378a-56e3-48ac-9b3c-04c0400a4325} TCPHandler: Code: 35. DB::Exception: Function arrayFold requires as arguments a lambda function, at least one array and an accumulator: In scope SELECT arrayFold([], []). (TOO_FEW_ARGUMENTS_FOR_FUNCTION) 2025.10.23 23:30:00.720237 [ 3006 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:00.863382 [ 3010 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:00.969679 [ 6609 ] {c6909202-8598-483e-be0f-3fd3db43c790} executeQuery: Code: 43. DB::Exception: array aggregate functions cannot be performed on two empty arrays: In scope SELECT arrayJaccardIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayJaccardIndex([], []);) 2025.10.23 23:30:00.972835 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:00.973359 [ 6609 ] {c6909202-8598-483e-be0f-3fd3db43c790} TCPHandler: Code: 43. DB::Exception: array aggregate functions cannot be performed on two empty arrays: In scope SELECT arrayJaccardIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:01.062738 [ 6609 ] {45be8c78-c0b3-465c-b204-ad4d476c0f5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayJoin([], []);) 2025.10.23 23:30:01.074068 [ 6609 ] {45be8c78-c0b3-465c-b204-ad4d476c0f5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayJoin doesn't match: passed 2, should be 1: In scope SELECT arrayJoin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:01.207898 [ 3495 ] {60987ce0-72a5-4a0d-8b16-70a807fee056} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:01.212308 [ 3495 ] {60987ce0-72a5-4a0d-8b16-70a807fee056} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:01.228721 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (3 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:01.242426 [ 6609 ] {679aea4f-beb1-4d1c-b66e-da10bb97e401} executeQuery: Code: 43. DB::Exception: First argument for function arrayLast must be a function. Actual Array(Nothing): In scope SELECT arrayLast([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayLast([], []);) 2025.10.23 23:30:01.256309 [ 6609 ] {679aea4f-beb1-4d1c-b66e-da10bb97e401} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLast must be a function. Actual Array(Nothing): In scope SELECT arrayLast([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:01.389154 [ 6609 ] {da5f0f47-aaf5-438e-9afa-1964efedd1c2} executeQuery: Code: 43. DB::Exception: First argument for function arrayLastIndex must be a function. Actual Array(Nothing): In scope SELECT arrayLastIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayLastIndex([], []);) 2025.10.23 23:30:01.395589 [ 6609 ] {da5f0f47-aaf5-438e-9afa-1964efedd1c2} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLastIndex must be a function. Actual Array(Nothing): In scope SELECT arrayLastIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:01.482896 [ 6609 ] {3504f275-98f4-4973-b4a6-5812bb147c00} executeQuery: Code: 43. DB::Exception: First argument for function arrayLastOrNull must be a function. Actual Array(Nothing): In scope SELECT arrayLastOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayLastOrNull([], []);) 2025.10.23 23:30:01.536629 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:01.586676 [ 6609 ] {3504f275-98f4-4973-b4a6-5812bb147c00} TCPHandler: Code: 43. DB::Exception: First argument for function arrayLastOrNull must be a function. Actual Array(Nothing): In scope SELECT arrayLastOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:01.668964 [ 6609 ] {93d1ed80-e40c-4498-99de-8b3cfad7f70f} executeQuery: Code: 43. DB::Exception: First argument for function arrayMap must be a function. Actual Array(Nothing): In scope SELECT arrayMap([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayMap([], []);) 2025.10.23 23:30:01.676428 [ 6609 ] {93d1ed80-e40c-4498-99de-8b3cfad7f70f} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMap must be a function. Actual Array(Nothing): In scope SELECT arrayMap([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:01.722420 [ 3027 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:01.808104 [ 6609 ] {eb0721d8-d40d-4c7a-bef7-4aad207c68ed} executeQuery: Code: 43. DB::Exception: First argument for function arrayMax must be a function. Actual Array(Nothing): In scope SELECT arrayMax([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayMax([], []);) 2025.10.23 23:30:01.819538 [ 6609 ] {eb0721d8-d40d-4c7a-bef7-4aad207c68ed} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMax must be a function. Actual Array(Nothing): In scope SELECT arrayMax([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:01.865434 [ 3021 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:01.972878 [ 6609 ] {ab4d3100-d1d4-451c-a7d4-03e479c5bc5d} executeQuery: Code: 43. DB::Exception: First argument for function arrayMin must be a function. Actual Array(Nothing): In scope SELECT arrayMin([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayMin([], []);) 2025.10.23 23:30:01.977748 [ 6609 ] {ab4d3100-d1d4-451c-a7d4-03e479c5bc5d} TCPHandler: Code: 43. DB::Exception: First argument for function arrayMin must be a function. Actual Array(Nothing): In scope SELECT arrayMin([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:02.010844 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:02.136452 [ 6609 ] {d0f17c64-12e8-41a3-ab52-901f639eb3d9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of limit argument of function arrayPartialReverseSort (must be UInt or Int): In scope SELECT arrayPartialReverseSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayPartialReverseSort([], []);) 2025.10.23 23:30:02.150573 [ 6609 ] {d0f17c64-12e8-41a3-ab52-901f639eb3d9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of limit argument of function arrayPartialReverseSort (must be UInt or Int): In scope SELECT arrayPartialReverseSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:02.268904 [ 3654 ] {6530aced-254d-4510-ba0a-36069f650e61} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'StartDate' in scope SELECT any(0) FROM test.visits WHERE toInt32(toDateTime(StartDate)) > 1000000000. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57206) (comment: 00085_monotonic_evaluation_segfault.sql) (in query: SELECT any(0) FROM test.visits WHERE (toInt32(toDateTime(StartDate))) > 1000000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:30:02.275954 [ 3654 ] {6530aced-254d-4510-ba0a-36069f650e61} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'StartDate' in scope SELECT any(0) FROM test.visits WHERE toInt32(toDateTime(StartDate)) > 1000000000. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:30:02.294141 [ 6609 ] {d2f1f37d-2c92-40bd-ac71-ea0a5cf5881f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of arguments of function arrayPartialShuffle (must be UInt or Int): In scope SELECT arrayPartialShuffle([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayPartialShuffle([], []);) 2025.10.23 23:30:02.306006 [ 6609 ] {d2f1f37d-2c92-40bd-ac71-ea0a5cf5881f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of arguments of function arrayPartialShuffle (must be UInt or Int): In scope SELECT arrayPartialShuffle([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:02.434819 [ 6609 ] {9730123d-977d-4ba0-a642-fbdcd0ec5ff3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayPartialSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayPartialSort([], []);) 2025.10.23 23:30:02.442870 [ 6609 ] {9730123d-977d-4ba0-a642-fbdcd0ec5ff3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of limit argument of function arrayPartialSort (must be UInt or Int): In scope SELECT arrayPartialSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:02.573186 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:02.587283 [ 6609 ] {c5964d7d-0276-4bf1-8f28-ed4e6e5fa67f} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayPopBack([], []);) 2025.10.23 23:30:02.599935 [ 6609 ] {c5964d7d-0276-4bf1-8f28-ed4e6e5fa67f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopBack doesn't match: passed 2, should be 1: In scope SELECT arrayPopBack([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:02.699205 [ 6609 ] {14f726a4-7022-4bba-b598-b1ee077d6d85} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayPopFront([], []);) 2025.10.23 23:30:02.707527 [ 6609 ] {14f726a4-7022-4bba-b598-b1ee077d6d85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayPopFront doesn't match: passed 2, should be 1: In scope SELECT arrayPopFront([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:02.724506 [ 3042 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:02.843748 [ 6609 ] {4b8f7d5e-dca8-40e0-86b4-c7706d1f9b11} executeQuery: Code: 43. DB::Exception: First argument for function arrayProduct must be a function. Actual Array(Nothing): In scope SELECT arrayProduct([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayProduct([], []);) 2025.10.23 23:30:02.850209 [ 6609 ] {4b8f7d5e-dca8-40e0-86b4-c7706d1f9b11} TCPHandler: Code: 43. DB::Exception: First argument for function arrayProduct must be a function. Actual Array(Nothing): In scope SELECT arrayProduct([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:02.867606 [ 3043 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:03.102093 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:03.287742 [ 6609 ] {01b19a6a-d799-4b47-af46-9b3383034ca3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Array(Nothing): In scope SELECT arrayRandomSample([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayRandomSample([], []);) 2025.10.23 23:30:03.300504 [ 6609 ] {01b19a6a-d799-4b47-af46-9b3383034ca3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'samples' to function 'arrayRandomSample'. Expected: const UInt*, got: Array(Nothing): In scope SELECT arrayRandomSample([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:03.423363 [ 6609 ] {cd6b96d6-d7cb-4a85-96e1-d7f27ec17ba2} executeQuery: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayReduce([], []);) 2025.10.23 23:30:03.429552 [ 6609 ] {cd6b96d6-d7cb-4a85-96e1-d7f27ec17ba2} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReduce must be constant string: name of aggregate function.: In scope SELECT arrayReduce([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:03.552585 [ 6609 ] {df14725c-8299-4d8f-96a9-db2cbfa54dad} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 2, should be at least 3.: In scope SELECT arrayReduceInRanges([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayReduceInRanges([], []);) 2025.10.23 23:30:03.566318 [ 6609 ] {df14725c-8299-4d8f-96a9-db2cbfa54dad} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReduceInRanges doesn't match: passed 2, should be at least 3.: In scope SELECT arrayReduceInRanges([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:03.620352 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:03.627555 [ 6609 ] {0add8220-3d8f-4f7c-9594-81ce70615860} executeQuery: Code: 43. DB::Exception: Function arrayResize cannot resize Array(Nothing): In scope SELECT arrayResize([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayResize([], []);) 2025.10.23 23:30:03.634707 [ 6609 ] {0add8220-3d8f-4f7c-9594-81ce70615860} TCPHandler: Code: 43. DB::Exception: Function arrayResize cannot resize Array(Nothing): In scope SELECT arrayResize([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:03.723167 [ 6609 ] {3a3aa18a-2563-4043-88ab-a5ae0f5719a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayReverse([], []);) 2025.10.23 23:30:03.727024 [ 3064 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:03.729355 [ 6609 ] {3a3aa18a-2563-4043-88ab-a5ae0f5719a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayReverse doesn't match: passed 2, should be 1: In scope SELECT arrayReverse([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:03.857380 [ 6610 ] {71c38c57-9f03-4710-bd99-4cc3f7afefe8} 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.10542.altinitytest (altinity build)) (from [::1]:57240) (comment: 00065_loyalty_with_storage_join.sql) (in query: INSERT INTO join SELECT UserID, toInt8(if((sum(SearchEngineID = 2) AS yandex) > (sum(SearchEngineID = 3) AS google), yandex / (yandex + google), -google / (yandex + google)) * 10) AS loyalty FROM hits WHERE (SearchEngineID = 2) OR (SearchEngineID = 3) GROUP BY UserID HAVING (yandex + google) > 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d362b87 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:30:03.870064 [ 3068 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:03.873379 [ 6609 ] {76a7edce-1a92-4bab-9075-3462acf60418} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseFill must be a function. Actual Array(Nothing): In scope SELECT arrayReverseFill([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayReverseFill([], []);) 2025.10.23 23:30:03.876320 [ 6610 ] {71c38c57-9f03-4710-bd99-4cc3f7afefe8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d362b87 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:30:03.888726 [ 6609 ] {76a7edce-1a92-4bab-9075-3462acf60418} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseFill must be a function. Actual Array(Nothing): In scope SELECT arrayReverseFill([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:03.993972 [ 6609 ] {52d264d0-f873-46cc-ab6d-3b2c75d36ce9} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseSort must be a function. Actual Array(Nothing): In scope SELECT arrayReverseSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayReverseSort([], []);) 2025.10.23 23:30:03.999069 [ 6609 ] {52d264d0-f873-46cc-ab6d-3b2c75d36ce9} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseSort must be a function. Actual Array(Nothing): In scope SELECT arrayReverseSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.077746 [ 6609 ] {bc0da1d9-df44-45b0-ab19-3473eb3bd0c3} executeQuery: Code: 43. DB::Exception: First argument for function arrayReverseSplit must be a function. Actual Array(Nothing): In scope SELECT arrayReverseSplit([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayReverseSplit([], []);) 2025.10.23 23:30:04.084552 [ 6609 ] {bc0da1d9-df44-45b0-ab19-3473eb3bd0c3} TCPHandler: Code: 43. DB::Exception: First argument for function arrayReverseSplit must be a function. Actual Array(Nothing): In scope SELECT arrayReverseSplit([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.143889 [ 6609 ] {45351208-5ff8-4d3a-8297-a9fc5f2d9851} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayRotateLeft, expected Native Integer: In scope SELECT arrayRotateLeft([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayRotateLeft([], []);) 2025.10.23 23:30:04.152518 [ 6609 ] {45351208-5ff8-4d3a-8297-a9fc5f2d9851} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayRotateLeft, expected Native Integer: In scope SELECT arrayRotateLeft([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.208775 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:04.210962 [ 6609 ] {ee95b387-f76e-40a4-a11c-2a507dbecaca} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayRotateRight, expected Native Integer: In scope SELECT arrayRotateRight([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayRotateRight([], []);) 2025.10.23 23:30:04.217171 [ 6609 ] {ee95b387-f76e-40a4-a11c-2a507dbecaca} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayRotateRight, expected Native Integer: In scope SELECT arrayRotateRight([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.340755 [ 6609 ] {961d4611-9905-4e25-9d76-eb6df0f29682} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayShiftLeft, expected Native Integer: In scope SELECT arrayShiftLeft([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayShiftLeft([], []);) 2025.10.23 23:30:04.346512 [ 6609 ] {961d4611-9905-4e25-9d76-eb6df0f29682} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayShiftLeft, expected Native Integer: In scope SELECT arrayShiftLeft([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.465130 [ 6609 ] {23f399ad-d6b5-4a95-8eec-5fc2b5e9fb97} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayShiftRight, expected Native Integer: In scope SELECT arrayShiftRight([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayShiftRight([], []);) 2025.10.23 23:30:04.487593 [ 6609 ] {23f399ad-d6b5-4a95-8eec-5fc2b5e9fb97} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayShiftRight, expected Native Integer: In scope SELECT arrayShiftRight([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.605794 [ 6609 ] {8781f5b0-8c5e-46a3-9a31-97685a0804c4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'length' to function 'arrayShingles'. Expected: Integer, got: Array(Nothing): In scope SELECT arrayShingles([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayShingles([], []);) 2025.10.23 23:30:04.613489 [ 6609 ] {8781f5b0-8c5e-46a3-9a31-97685a0804c4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'length' to function 'arrayShingles'. Expected: Integer, got: Array(Nothing): In scope SELECT arrayShingles([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.699920 [ 6609 ] {a96027fe-ba9d-49b9-9d6d-518394a69f83} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayShuffle([], []);) 2025.10.23 23:30:04.706690 [ 6609 ] {a96027fe-ba9d-49b9-9d6d-518394a69f83} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of arguments of function arrayShuffle (must be UInt or Int): In scope SELECT arrayShuffle([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.729372 [ 3084 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:04.777730 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:04.807235 [ 6609 ] {4ca86b8a-a76e-4000-811f-6f714e8dabc0} executeQuery: Code: 43. DB::Exception: Argument 1 for function arraySlice must be integer but it has type Array(Nothing).: In scope SELECT arraySlice([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arraySlice([], []);) 2025.10.23 23:30:04.817567 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:04.825354 [ 6609 ] {4ca86b8a-a76e-4000-811f-6f714e8dabc0} TCPHandler: Code: 43. DB::Exception: Argument 1 for function arraySlice must be integer but it has type Array(Nothing).: In scope SELECT arraySlice([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:04.872244 [ 3086 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:04.905955 [ 6609 ] {45dc3eb9-fed3-4a95-8b0a-74ebb2a31c03} executeQuery: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Nothing): In scope SELECT arraySort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arraySort([], []);) 2025.10.23 23:30:04.912028 [ 6609 ] {45dc3eb9-fed3-4a95-8b0a-74ebb2a31c03} TCPHandler: Code: 43. DB::Exception: First argument for function arraySort must be a function. Actual Array(Nothing): In scope SELECT arraySort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:05.067168 [ 6609 ] {d4c58e66-09e5-4d36-9c66-e1ccaafd5adb} executeQuery: Code: 43. DB::Exception: First argument for function arraySplit must be a function. Actual Array(Nothing): In scope SELECT arraySplit([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arraySplit([], []);) 2025.10.23 23:30:05.073690 [ 6609 ] {d4c58e66-09e5-4d36-9c66-e1ccaafd5adb} TCPHandler: Code: 43. DB::Exception: First argument for function arraySplit must be a function. Actual Array(Nothing): In scope SELECT arraySplit([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:05.099568 [ 3654 ] {1ba900ce-0ee0-4a59-819b-10f6d7d0026c} executeQuery: Code: 1. DB::Exception: Resolve identifier 'StartDate' from parent scope only supported for constants and CTE. Actual test.hits.StartDate node type COLUMN. In scope SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate. (UNSUPPORTED_METHOD) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54420) (comment: 00043_any_left_join.sql) (in query: SELECT EventDate, count() AS hits, any(visits) FROM test.hits ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate GROUP BY EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, char const*&&, String&&) @ 0x00000000283cf486 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1267: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002839194f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838fc38 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 12. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c85ac 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4eee 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:30:05.123581 [ 3654 ] {1ba900ce-0ee0-4a59-819b-10f6d7d0026c} TCPHandler: Code: 1. DB::Exception: Resolve identifier 'StartDate' from parent scope only supported for constants and CTE. Actual test.hits.StartDate node type COLUMN. In scope SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate. (UNSUPPORTED_METHOD), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&&, char const*&&, String&&) @ 0x00000000283cf486 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1267: DB::QueryAnalyzer::tryResolveIdentifierInParentScopes(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x000000002839194f 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838fc38 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 12. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c85ac 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4eee 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:30:05.283885 [ 6609 ] {2ad7edf5-8bc9-44a7-9ab5-21b7456210b9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'separator' to function 'arrayStringConcat'. Expected: const String, got: Array(Nothing): In scope SELECT arrayStringConcat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayStringConcat([], []);) 2025.10.23 23:30:05.290010 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:05.292832 [ 6609 ] {2ad7edf5-8bc9-44a7-9ab5-21b7456210b9} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'separator' to function 'arrayStringConcat'. Expected: const String, got: Array(Nothing): In scope SELECT arrayStringConcat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:05.404917 [ 6609 ] {4a75cd20-68af-44b2-97b1-a5990c084c59} executeQuery: Code: 43. DB::Exception: First argument for function arraySum must be a function. Actual Array(Nothing): In scope SELECT arraySum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arraySum([], []);) 2025.10.23 23:30:05.411491 [ 6609 ] {4a75cd20-68af-44b2-97b1-a5990c084c59} TCPHandler: Code: 43. DB::Exception: First argument for function arraySum must be a function. Actual Array(Nothing): In scope SELECT arraySum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:05.666606 [ 6609 ] {e3eb526a-ec98-40e9-b704-466120ef34cd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT arrayWithConstant([], []);) 2025.10.23 23:30:05.679295 [ 6609 ] {e3eb526a-ec98-40e9-b704-466120ef34cd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function arrayWithConstant, expected Integer: In scope SELECT arrayWithConstant([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:05.731306 [ 3103 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:05.838669 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:05.874377 [ 3102 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:05.952260 [ 4227 ] {674b5d71-93f6-40bc-882b-20a8c4dcebe4} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:05.958214 [ 4227 ] {674b5d71-93f6-40bc-882b-20a8c4dcebe4} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:05.968859 [ 6609 ] {7e9fc365-c5a7-478d-9b17-4dbf89b2efad} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT array_agg([], []);) 2025.10.23 23:30:05.973190 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (4 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:05.978120 [ 6609 ] {7e9fc365-c5a7-478d-9b17-4dbf89b2efad} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:06.095007 [ 6609 ] {09363ad1-9758-4172-850b-1d2b4c261d71} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT array_concat_agg([], []);) 2025.10.23 23:30:06.105886 [ 6609 ] {09363ad1-9758-4172-850b-1d2b4c261d71} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:06.232853 [ 6609 ] {0527eee6-1728-447f-b7f4-7737eaff732f} executeQuery: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ascii([], []);) 2025.10.23 23:30:06.237129 [ 6609 ] {0527eee6-1728-447f-b7f4-7737eaff732f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function ascii doesn't match: passed 2, should be 1: In scope SELECT ascii([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:06.293822 [ 6609 ] {9f57af1c-575d-46ea-af1c-efb09b7338bb} executeQuery: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT asin([], []);) 2025.10.23 23:30:06.298593 [ 6609 ] {9f57af1c-575d-46ea-af1c-efb09b7338bb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asin doesn't match: passed 2, should be 1: In scope SELECT asin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:06.331997 [ 3654 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:06.357894 [ 6609 ] {c30f89ed-0f9b-4f23-bcd4-ab8503e37b2b} executeQuery: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT asinh([], []);) 2025.10.23 23:30:06.365454 [ 6609 ] {c30f89ed-0f9b-4f23-bcd4-ab8503e37b2b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function asinh doesn't match: passed 2, should be 1: In scope SELECT asinh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:06.446292 [ 6609 ] {0babf727-6531-4447-9528-999c26e0e070} executeQuery: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT assumeNotNull([], []);) 2025.10.23 23:30:06.452755 [ 6609 ] {0babf727-6531-4447-9528-999c26e0e070} TCPHandler: Code: 42. DB::Exception: Number of arguments for function assumeNotNull doesn't match: passed 2, should be 1: In scope SELECT assumeNotNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:06.520001 [ 6609 ] {1b4a2b8e-b343-4dfa-9a6d-8aff38cc7623} executeQuery: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT atan([], []);) 2025.10.23 23:30:06.523877 [ 6609 ] {1b4a2b8e-b343-4dfa-9a6d-8aff38cc7623} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atan doesn't match: passed 2, should be 1: In scope SELECT atan([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:06.531173 [ 4419 ] {c9ea944d-a681-40bb-86a9-07d0a7795f93} executeQuery: Code: 57. DB::Exception: Table test.hits_tinylog already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54440) (comment: 00077_log_tinylog_stripelog.sql) (in query: CREATE TABLE test.hits_tinylog (CounterID UInt32, AdvEngineID UInt8, RegionID UInt32, SearchPhrase String, UserID UInt64) ENGINE = TinyLog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:30:06.550521 [ 4419 ] {c9ea944d-a681-40bb-86a9-07d0a7795f93} TCPHandler: Code: 57. DB::Exception: Table test.hits_tinylog already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:30:06.626624 [ 6609 ] {d6813c6a-80dd-4f9a-9851-a6fc3ba5428a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function atan2: In scope SELECT atan2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT atan2([], []);) 2025.10.23 23:30:06.632876 [ 6609 ] {d6813c6a-80dd-4f9a-9851-a6fc3ba5428a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function atan2: In scope SELECT atan2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:06.733453 [ 3117 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:06.831685 [ 6609 ] {02cb50a7-647c-4be4-891c-36a69f962ae5} executeQuery: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT atanh([], []);) 2025.10.23 23:30:06.835356 [ 6609 ] {02cb50a7-647c-4be4-891c-36a69f962ae5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function atanh doesn't match: passed 2, should be 1: In scope SELECT atanh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:06.876432 [ 3122 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:06.888459 [ 3654 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:06.889647 [ 3495 ] {f48f644c-6388-4339-9e50-961b8f48d010} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:06.892372 [ 3495 ] {f48f644c-6388-4339-9e50-961b8f48d010} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:06.914847 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (4 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:06.936979 [ 6609 ] {de3ae5cc-d404-4d0c-9151-06ae5ae92960} executeQuery: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT avg([], []);) 2025.10.23 23:30:06.954301 [ 6609 ] {de3ae5cc-d404-4d0c-9151-06ae5ae92960} TCPHandler: Code: 42. DB::Exception: Aggregate function avg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:07.052609 [ 6609 ] {66f56a6a-2bc4-4a01-943e-68817c7ec4c2} executeQuery: Code: 43. DB::Exception: Types Array(Nothing) and Array(Nothing) are non-conforming as arguments for aggregate function avgWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT avgWeighted([], []);) 2025.10.23 23:30:07.062443 [ 6609 ] {66f56a6a-2bc4-4a01-943e-68817c7ec4c2} TCPHandler: Code: 43. DB::Exception: Types Array(Nothing) and Array(Nothing) are non-conforming as arguments for aggregate function avgWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:07.204321 [ 6609 ] {11311b35-8593-48cf-aaf0-c48b7658b704} executeQuery: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 2.: In scope SELECT bar([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bar([], []);) 2025.10.23 23:30:07.211538 [ 6609 ] {11311b35-8593-48cf-aaf0-c48b7658b704} TCPHandler: Code: 42. DB::Exception: Function bar requires from 3 or 4 parameters: value, min_value, max_value, [max_width_of_bar = 80]. Passed 2.: In scope SELECT bar([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:07.338931 [ 6609 ] {e11ce3e2-175a-4503-b5d8-73b88152390f} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT base58Decode([], []);) 2025.10.23 23:30:07.342638 [ 6609 ] {e11ce3e2-175a-4503-b5d8-73b88152390f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Decode doesn't match: passed 2, should be 1: In scope SELECT base58Decode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:07.378458 [ 3654 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:07.431702 [ 6609 ] {3def6a50-4263-4b03-8a2f-a4a94c3603bc} executeQuery: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT base58Encode([], []);) 2025.10.23 23:30:07.448938 [ 6609 ] {3def6a50-4263-4b03-8a2f-a4a94c3603bc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base58Encode doesn't match: passed 2, should be 1: In scope SELECT base58Encode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:07.613285 [ 6609 ] {267ff7f8-e260-404f-ac87-9aeee94f4346} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT base64Decode([], []);) 2025.10.23 23:30:07.618153 [ 6609 ] {267ff7f8-e260-404f-ac87-9aeee94f4346} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Decode doesn't match: passed 2, should be 1: In scope SELECT base64Decode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:07.736249 [ 3134 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:07.790199 [ 6609 ] {37fff805-e29e-40e4-b275-ad6ffe7b1f4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT base64Encode([], []);) 2025.10.23 23:30:07.795079 [ 6609 ] {37fff805-e29e-40e4-b275-ad6ffe7b1f4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64Encode doesn't match: passed 2, should be 1: In scope SELECT base64Encode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:07.873069 [ 6609 ] {a6882e55-9335-41d6-be68-cdb6c8adb198} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT base64URLDecode([], []);) 2025.10.23 23:30:07.878771 [ 3141 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:07.882230 [ 6609 ] {a6882e55-9335-41d6-be68-cdb6c8adb198} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLDecode doesn't match: passed 2, should be 1: In scope SELECT base64URLDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:07.914629 [ 6610 ] {9aa283cf-6f74-4b3d-a265-f8cb46c74193} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT dictHas('db_dict.cache_hits', toUInt64(WatchID)) AS flag FROM test.hits PREWHERE (WatchID % 1400) = 0 LIMIT 100. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54464) (comment: 00158_cache_dictionary_has.sql) (in query: SELECT sum(flag) FROM (SELECT dictHas('db_dict.cache_hits', toUInt64(WatchID)) as flag FROM test.hits PREWHERE WatchID % 1400 == 0 LIMIT 100);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:30:07.934013 [ 6610 ] {9aa283cf-6f74-4b3d-a265-f8cb46c74193} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT dictHas('db_dict.cache_hits', toUInt64(WatchID)) AS flag FROM test.hits PREWHERE (WatchID % 1400) = 0 LIMIT 100. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:30:07.968925 [ 6609 ] {1cc4f11c-0cf2-4cfe-8a21-db36b014ffa2} executeQuery: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT base64URLEncode([], []);) 2025.10.23 23:30:07.993500 [ 3654 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:07.994686 [ 6609 ] {1cc4f11c-0cf2-4cfe-8a21-db36b014ffa2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function base64URLEncode doesn't match: passed 2, should be 1: In scope SELECT base64URLEncode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:08.138017 [ 6609 ] {57976851-d3ce-4059-866e-be6da7d66ae8} executeQuery: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT basename([], []);) 2025.10.23 23:30:08.142946 [ 6609 ] {57976851-d3ce-4059-866e-be6da7d66ae8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function basename doesn't match: passed 2, should be 1: In scope SELECT basename([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:08.221049 [ 6609 ] {0104b18e-84eb-4537-bce4-2d626ac63ae4} executeQuery: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bin([], []);) 2025.10.23 23:30:08.227853 [ 6609 ] {0104b18e-84eb-4537-bce4-2d626ac63ae4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bin doesn't match: passed 2, should be 1: In scope SELECT bin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:08.375134 [ 6609 ] {7eeb821e-995d-4707-b166-b9bef0af3582} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitAnd: In scope SELECT bitAnd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitAnd([], []);) 2025.10.23 23:30:08.385126 [ 6609 ] {7eeb821e-995d-4707-b166-b9bef0af3582} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitAnd: In scope SELECT bitAnd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:08.456214 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:08.468954 [ 6609 ] {fa307bd5-6bee-4a48-a6b0-da76ad28463b} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitCount([], []);) 2025.10.23 23:30:08.486976 [ 6609 ] {fa307bd5-6bee-4a48-a6b0-da76ad28463b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitCount doesn't match: passed 2, should be 1: In scope SELECT bitCount([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:08.612748 [ 6609 ] {30ce469f-a256-4481-87b2-d22490059d5d} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitHammingDistance: In scope SELECT bitHammingDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitHammingDistance([], []);) 2025.10.23 23:30:08.638228 [ 6609 ] {30ce469f-a256-4481-87b2-d22490059d5d} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitHammingDistance: In scope SELECT bitHammingDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:08.738704 [ 3156 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:08.786315 [ 6609 ] {8baddcd2-806a-4b24-acd8-728caa01c32a} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitNot([], []);) 2025.10.23 23:30:08.799570 [ 6609 ] {8baddcd2-806a-4b24-acd8-728caa01c32a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitNot doesn't match: passed 2, should be 1: In scope SELECT bitNot([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:08.880976 [ 3164 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:08.887019 [ 6609 ] {2baef5cb-8511-4b37-a79b-f5434a98f06d} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitOr: In scope SELECT bitOr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitOr([], []);) 2025.10.23 23:30:08.899620 [ 6609 ] {2baef5cb-8511-4b37-a79b-f5434a98f06d} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitOr: In scope SELECT bitOr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:08.969276 [ 6609 ] {0a7499e1-fd43-4fa3-9711-fe299d0fcec6} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitPositionsToArray([], []);) 2025.10.23 23:30:08.974474 [ 6609 ] {0a7499e1-fd43-4fa3-9711-fe299d0fcec6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitPositionsToArray doesn't match: passed 2, should be 1: In scope SELECT bitPositionsToArray([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:09.055565 [ 3654 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:09.067282 [ 6609 ] {55946213-231d-4806-9303-33e675a1a6d4} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitRotateLeft([], []);) 2025.10.23 23:30:09.078457 [ 6609 ] {55946213-231d-4806-9303-33e675a1a6d4} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitRotateLeft: In scope SELECT bitRotateLeft([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:09.212512 [ 6609 ] {abc400d5-682c-4b9d-993c-add7e7d6757b} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitRotateRight: In scope SELECT bitRotateRight([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitRotateRight([], []);) 2025.10.23 23:30:09.220114 [ 6609 ] {abc400d5-682c-4b9d-993c-add7e7d6757b} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitRotateRight: In scope SELECT bitRotateRight([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:09.316311 [ 6609 ] {718db177-ba79-4b1d-b998-fb6e11183cd4} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitShiftLeft([], []);) 2025.10.23 23:30:09.322306 [ 6609 ] {718db177-ba79-4b1d-b998-fb6e11183cd4} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitShiftLeft: In scope SELECT bitShiftLeft([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:09.437714 [ 6609 ] {5cc1841d-5a20-40cf-928c-6c8c611ad0a6} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitShiftRight: In scope SELECT bitShiftRight([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitShiftRight([], []);) 2025.10.23 23:30:09.449167 [ 6609 ] {5cc1841d-5a20-40cf-928c-6c8c611ad0a6} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitShiftRight: In scope SELECT bitShiftRight([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:09.505690 [ 3654 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:09.613637 [ 6609 ] {3ce15aea-d10e-45cb-9a18-5f22f07443a5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: Array(Nothing): In scope SELECT bitSlice([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitSlice([], []);) 2025.10.23 23:30:09.635039 [ 6609 ] {3ce15aea-d10e-45cb-9a18-5f22f07443a5} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'bitSlice'. Expected: String, got: Array(Nothing): In scope SELECT bitSlice([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:09.745069 [ 3184 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:09.757519 [ 6609 ] {2caba91a-2e32-4c6d-8d50-0dce10e5cc7c} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitTest: In scope SELECT bitTest([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitTest([], []);) 2025.10.23 23:30:09.766455 [ 6609 ] {2caba91a-2e32-4c6d-8d50-0dce10e5cc7c} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitTest: In scope SELECT bitTest([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:09.883184 [ 3181 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:09.893714 [ 6609 ] {84af96eb-72e8-44e8-87d6-5d96ac11bac7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function bitTestAll: In scope SELECT bitTestAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitTestAll([], []);) 2025.10.23 23:30:09.926363 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:09.995123 [ 6609 ] {84af96eb-72e8-44e8-87d6-5d96ac11bac7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function bitTestAll: In scope SELECT bitTestAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:10.061972 [ 6609 ] {0918644a-2182-448e-b555-f49b4e06e3db} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function bitTestAny: In scope SELECT bitTestAny([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitTestAny([], []);) 2025.10.23 23:30:10.067616 [ 6609 ] {0918644a-2182-448e-b555-f49b4e06e3db} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function bitTestAny: In scope SELECT bitTestAny([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:10.087599 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:10.152124 [ 6609 ] {d40e4ce8-12a7-4b36-9d1d-21ef749ce3da} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitXor: In scope SELECT bitXor([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitXor([], []);) 2025.10.23 23:30:10.165473 [ 6609 ] {d40e4ce8-12a7-4b36-9d1d-21ef749ce3da} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function bitXor: In scope SELECT bitXor([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:10.310115 [ 6609 ] {585b58e8-a604-4478-91f2-d13099b60d31} executeQuery: Code: 43. DB::Exception: First argument for function bitmapAnd must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapAnd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapAnd([], []);) 2025.10.23 23:30:10.316057 [ 6609 ] {585b58e8-a604-4478-91f2-d13099b60d31} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapAnd must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapAnd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:10.434574 [ 6609 ] {a67886d4-08e5-4ec1-924f-cae7d61add3c} executeQuery: Code: 43. DB::Exception: First argument for function bitmapAndCardinality must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapAndCardinality([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapAndCardinality([], []);) 2025.10.23 23:30:10.442924 [ 6609 ] {a67886d4-08e5-4ec1-924f-cae7d61add3c} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapAndCardinality must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapAndCardinality([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:10.535094 [ 6609 ] {cf1744a4-f9d3-4722-a9ee-ef3943e43f7d} executeQuery: Code: 43. DB::Exception: First argument for function bitmapAndnot must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapAndnot([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapAndnot([], []);) 2025.10.23 23:30:10.541772 [ 6609 ] {cf1744a4-f9d3-4722-a9ee-ef3943e43f7d} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapAndnot must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapAndnot([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:10.613749 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:10.715284 [ 6609 ] {367ade52-6d29-4ee7-ba32-f3506eddf1a1} executeQuery: Code: 43. DB::Exception: First argument for function bitmapAndnotCardinality must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapAndnotCardinality([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapAndnotCardinality([], []);) 2025.10.23 23:30:10.718165 [ 6609 ] {367ade52-6d29-4ee7-ba32-f3506eddf1a1} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapAndnotCardinality must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapAndnotCardinality([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:10.747364 [ 3196 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:10.829838 [ 6609 ] {189ed083-0056-4a42-a2f4-33150044b27c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapBuild([], []);) 2025.10.23 23:30:10.840527 [ 6609 ] {189ed083-0056-4a42-a2f4-33150044b27c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapBuild doesn't match: passed 2, should be 1: In scope SELECT bitmapBuild([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:10.885522 [ 3199 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:10.943058 [ 6609 ] {9c5630b4-1794-4ded-b2f4-673a8d8bcb4e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapCardinality([], []);) 2025.10.23 23:30:10.952448 [ 6609 ] {9c5630b4-1794-4ded-b2f4-673a8d8bcb4e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapCardinality doesn't match: passed 2, should be 1: In scope SELECT bitmapCardinality([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:11.044964 [ 6609 ] {cf37f1d1-2516-433b-b249-d591b6358489} executeQuery: Code: 43. DB::Exception: First argument for function bitmapContains must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapContains([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapContains([], []);) 2025.10.23 23:30:11.050786 [ 6609 ] {cf37f1d1-2516-433b-b249-d591b6358489} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapContains must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapContains([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:11.110893 [ 6609 ] {5b671db9-4fd3-4f88-98b6-975aea9154a3} executeQuery: Code: 43. DB::Exception: First argument for function bitmapHasAll must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapHasAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapHasAll([], []);) 2025.10.23 23:30:11.115258 [ 6609 ] {5b671db9-4fd3-4f88-98b6-975aea9154a3} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapHasAll must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapHasAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:11.115333 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:11.195047 [ 6609 ] {7fcc01f3-8108-4651-91b5-0c25ed34b99e} executeQuery: Code: 43. DB::Exception: First argument for function bitmapHasAny must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapHasAny([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapHasAny([], []);) 2025.10.23 23:30:11.223363 [ 6609 ] {7fcc01f3-8108-4651-91b5-0c25ed34b99e} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapHasAny must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapHasAny([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:11.282804 [ 6609 ] {933bd71d-3a84-447a-9509-d812edd16188} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapMax([], []);) 2025.10.23 23:30:11.289348 [ 6609 ] {933bd71d-3a84-447a-9509-d812edd16188} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMax doesn't match: passed 2, should be 1: In scope SELECT bitmapMax([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:11.378387 [ 6609 ] {cfcd1076-975d-4d95-a852-6f78553599cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapMin([], []);) 2025.10.23 23:30:11.388133 [ 6609 ] {cfcd1076-975d-4d95-a852-6f78553599cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapMin doesn't match: passed 2, should be 1: In scope SELECT bitmapMin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:11.521967 [ 6609 ] {8c1182af-be27-4010-8ff9-b0cb9400f09c} executeQuery: Code: 43. DB::Exception: First argument for function bitmapOr must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapOr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapOr([], []);) 2025.10.23 23:30:11.527584 [ 6609 ] {8c1182af-be27-4010-8ff9-b0cb9400f09c} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapOr must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapOr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:11.626003 [ 4227 ] {c5c1afcf-c64f-4a38-8478-20d2b09c638c} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:11.628119 [ 6609 ] {9d26c30d-03b9-4801-9c20-09bf2976df4a} executeQuery: Code: 43. DB::Exception: First argument for function bitmapOrCardinality must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapOrCardinality([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapOrCardinality([], []);) 2025.10.23 23:30:11.629222 [ 4227 ] {c5c1afcf-c64f-4a38-8478-20d2b09c638c} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:11.632979 [ 6609 ] {9d26c30d-03b9-4801-9c20-09bf2976df4a} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapOrCardinality must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapOrCardinality([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:11.643197 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (5 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:11.663430 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:11.700929 [ 6609 ] {16810744-a114-44b4-be3b-3e830b1fab06} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapSubsetInRange([], []);) 2025.10.23 23:30:11.715076 [ 6609 ] {16810744-a114-44b4-be3b-3e830b1fab06} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetInRange doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetInRange([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:11.749426 [ 3210 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:11.822847 [ 6609 ] {ea87d123-6459-4326-863a-be816d66bde5} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapSubsetLimit([], []);) 2025.10.23 23:30:11.830165 [ 6609 ] {ea87d123-6459-4326-863a-be816d66bde5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapSubsetLimit doesn't match: passed 2, should be 3: In scope SELECT bitmapSubsetLimit([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:11.888170 [ 3212 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:11.914640 [ 6609 ] {8a5b8be8-c6e6-494e-97a2-40835d3bc348} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapToArray([], []);) 2025.10.23 23:30:11.919850 [ 6609 ] {8a5b8be8-c6e6-494e-97a2-40835d3bc348} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapToArray doesn't match: passed 2, should be 1: In scope SELECT bitmapToArray([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:12.034329 [ 6609 ] {612b63ab-f63c-4652-858c-f351610ed24e} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapTransform([], []);) 2025.10.23 23:30:12.042320 [ 6609 ] {612b63ab-f63c-4652-858c-f351610ed24e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmapTransform doesn't match: passed 2, should be 3: In scope SELECT bitmapTransform([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:12.065753 [ 4419 ] {0591d48f-e247-48a5-bac1-adcc230c5741} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54500) (comment: 00079_array_join_not_used_joined_column.sql) (in query: SELECT ParsedParams.Key2 AS x FROM test.hits ARRAY JOIN ParsedParams AS PP ORDER BY x DESC LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b7f0d7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ac0b55 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df07531 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 2025.10.23 23:30:12.080038 [ 4419 ] {0591d48f-e247-48a5-bac1-adcc230c5741} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./contrib/llvm-project/libcxx/include/vector:1647: DB::SerializationNamed::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027b7f0d7 13. ./build_docker/./src/DataTypes/Serializations/SerializationArray.cpp:0: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ac0b55 14. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 15. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 18. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolParallelReplicas.cpp:201: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df07531 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 24. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 25. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 29. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 2025.10.23 23:30:12.143072 [ 6609 ] {56d8b211-8a1b-4786-9d47-85f329d22d11} executeQuery: Code: 43. DB::Exception: First argument for function bitmapXor must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapXor([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapXor([], []);) 2025.10.23 23:30:12.150589 [ 6609 ] {56d8b211-8a1b-4786-9d47-85f329d22d11} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapXor must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapXor([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:12.151830 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:12.259994 [ 6609 ] {2f80ae2c-f1b4-45db-9f65-741fd55af578} executeQuery: Code: 43. DB::Exception: First argument for function bitmapXorCardinality must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapXorCardinality([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmapXorCardinality([], []);) 2025.10.23 23:30:12.266077 [ 6609 ] {2f80ae2c-f1b4-45db-9f65-741fd55af578} TCPHandler: Code: 43. DB::Exception: First argument for function bitmapXorCardinality must be a bitmap but it has type Array(Nothing): In scope SELECT bitmapXorCardinality([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:12.355890 [ 6609 ] {76929f57-c006-4c33-be72-3c1a438553e2} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmaskToArray([], []);) 2025.10.23 23:30:12.358621 [ 6609 ] {76929f57-c006-4c33-be72-3c1a438553e2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToArray doesn't match: passed 2, should be 1: In scope SELECT bitmaskToArray([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:12.423848 [ 6609 ] {0086e804-c8a1-4357-8d82-bb6accbd2d1c} executeQuery: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT bitmaskToList([], []);) 2025.10.23 23:30:12.438136 [ 6609 ] {0086e804-c8a1-4357-8d82-bb6accbd2d1c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function bitmaskToList doesn't match: passed 2, should be 1: In scope SELECT bitmaskToList([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:12.509820 [ 3495 ] {e424a9d2-517b-4d26-aa10-f57e6ce001e8} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:12.513427 [ 3495 ] {e424a9d2-517b-4d26-aa10-f57e6ce001e8} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:12.533521 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (5 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:12.537491 [ 6609 ] {87b81b66-86fe-4aae-a0c1-58ae2961ff6b} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT blockNumber([], []);) 2025.10.23 23:30:12.543830 [ 6609 ] {87b81b66-86fe-4aae-a0c1-58ae2961ff6b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockNumber doesn't match: passed 2, should be 0: In scope SELECT blockNumber([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:12.706868 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:12.751501 [ 3231 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:12.812393 [ 6609 ] {f9a71700-3ca6-4b17-9acf-c09aa070754a} executeQuery: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT blockSize([], []);) 2025.10.23 23:30:12.826743 [ 6609 ] {f9a71700-3ca6-4b17-9acf-c09aa070754a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function blockSize doesn't match: passed 2, should be 0: In scope SELECT blockSize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:12.835293 [ 4286 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:30:18: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:12.890170 [ 3235 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:12.959533 [ 6609 ] {7dcb3b86-9ead-4cf1-a86c-9e2c42e821b2} executeQuery: Code: 36. DB::Exception: Illegal types of arguments of aggregate function boundingRatio, must have number representation. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT boundingRatio([], []);) 2025.10.23 23:30:12.971974 [ 6609 ] {7dcb3b86-9ead-4cf1-a86c-9e2c42e821b2} TCPHandler: Code: 36. DB::Exception: Illegal types of arguments of aggregate function boundingRatio, must have number representation. (BAD_ARGUMENTS) 2025.10.23 23:30:13.006247 [ 4203 ] {df179850-739a-43b2-9ebb-92bd89624390} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URLDomain'. In scope WITH URLDomain AS a, URLDomain AS b SELECT round(cramersV(a, b), 2), round(cramersVBiasCorrected(a, b), 2), round(theilsU(a, b), 2), round(theilsU(b, a), 2), round(contingency(a, b), 2) FROM test.hits. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54582) (comment: 00169_contingency.sql) (in query: WITH URLDomain AS a, URLDomain AS b SELECT round(cramersV(a, b), 2), round(cramersVBiasCorrected(a, b), 2), round(theilsU(a, b), 2), round(theilsU(b, a), 2), round(contingency(a, b), 2) FROM test.hits;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x00000000283cef06 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1139: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838e46a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838f223 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:30:13.028539 [ 4203 ] {df179850-739a-43b2-9ebb-92bd89624390} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URLDomain'. In scope WITH URLDomain AS a, URLDomain AS b SELECT round(cramersV(a, b), 2), round(cramersVBiasCorrected(a, b), 2), round(theilsU(a, b), 2), round(theilsU(b, a), 2), round(contingency(a, b), 2) FROM test.hits. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String const&, String&&, String&&) @ 0x00000000283cef06 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1139: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838e46a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838f223 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:30:13.054368 [ 6609 ] {c6e116f3-4385-4bf2-a315-4c407203dbc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT buildId([], []);) 2025.10.23 23:30:13.062902 [ 6609 ] {c6e116f3-4385-4bf2-a315-4c407203dbc6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function buildId doesn't match: passed 2, should be 0: In scope SELECT buildId([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:13.174119 [ 6609 ] {e3a8ace9-41ae-4979-96a7-3518f01f2959} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function byteHammingDistance: In scope SELECT byteHammingDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT byteHammingDistance([], []);) 2025.10.23 23:30:13.181887 [ 6609 ] {e3a8ace9-41ae-4979-96a7-3518f01f2959} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function byteHammingDistance: In scope SELECT byteHammingDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:13.253862 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:13.536021 [ 6609 ] {a47ec9ae-77ea-4e56-b304-bb3f22b1de52} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT byteSlice([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT byteSlice([], []);) 2025.10.23 23:30:13.551254 [ 6609 ] {a47ec9ae-77ea-4e56-b304-bb3f22b1de52} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT byteSlice([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:13.671330 [ 6609 ] {89ff75ad-c7bb-4ee7-9609-9dcdf08d128c} executeQuery: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT byteSwap([], []);) 2025.10.23 23:30:13.690197 [ 6609 ] {89ff75ad-c7bb-4ee7-9609-9dcdf08d128c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function byteSwap doesn't match: passed 2, should be 1: In scope SELECT byteSwap([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:13.747351 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:13.756645 [ 3255 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:13.770220 [ 6609 ] {65efb5ac-d7e6-40f0-9a05-33cf76e4b0b5} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpr([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT caseWithExpr([], []);) 2025.10.23 23:30:13.784494 [ 6609 ] {65efb5ac-d7e6-40f0-9a05-33cf76e4b0b5} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpr([], []). (BAD_ARGUMENTS) 2025.10.23 23:30:13.892173 [ 3263 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:13.896346 [ 6609 ] {03ad665c-3bcc-4efe-883e-09bb1f62bd40} executeQuery: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpression([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT caseWithExpression([], []);) 2025.10.23 23:30:13.929878 [ 6609 ] {03ad665c-3bcc-4efe-883e-09bb1f62bd40} TCPHandler: Code: 36. DB::Exception: Unexpected type Array(Nothing) in function 'transform': In scope SELECT caseWithExpression([], []). (BAD_ARGUMENTS) 2025.10.23 23:30:14.038822 [ 6609 ] {ff3b5625-1759-4f63-b44a-80ae0504a01c} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT caseWithoutExpr([], []);) 2025.10.23 23:30:14.046211 [ 6609 ] {ff3b5625-1759-4f63-b44a-80ae0504a01c} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpr([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:14.145649 [ 6609 ] {cad5805f-29e6-4c41-b5f6-e934bf6f2359} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT caseWithoutExpression([], []);) 2025.10.23 23:30:14.161473 [ 6609 ] {cad5805f-29e6-4c41-b5f6-e934bf6f2359} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT caseWithoutExpression([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:14.281958 [ 6609 ] {c039abfe-3da7-46e1-a821-b5f6c15cade0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT catboostEvaluate([], []);) 2025.10.23 23:30:14.288377 [ 6609 ] {c039abfe-3da7-46e1-a821-b5f6c15cade0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function catboostEvaluate, expected a string.: In scope SELECT catboostEvaluate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:14.312826 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:14.418787 [ 6609 ] {fa55b07c-ddae-4795-9f24-7593d2bd1df6} executeQuery: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT categoricalInformationValue([], []);) 2025.10.23 23:30:14.431103 [ 6609 ] {fa55b07c-ddae-4795-9f24-7593d2bd1df6} TCPHandler: Code: 43. DB::Exception: All the arguments of aggregate function categoricalInformationValue should be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:14.540780 [ 6609 ] {286f385c-4a29-47f1-9a5c-ec09eaafcd8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cbrt([], []);) 2025.10.23 23:30:14.549282 [ 6609 ] {286f385c-4a29-47f1-9a5c-ec09eaafcd8d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cbrt doesn't match: passed 2, should be 1: In scope SELECT cbrt([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:14.679434 [ 6609 ] {3fe88e89-afdc-45f1-ae2d-f0787ea8e748} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'ceil'. Expected: A number to round, got: Array(Nothing): In scope SELECT ceil([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ceil([], []);) 2025.10.23 23:30:14.693064 [ 6609 ] {3fe88e89-afdc-45f1-ae2d-f0787ea8e748} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'ceil'. Expected: A number to round, got: Array(Nothing): In scope SELECT ceil([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:14.767307 [ 3273 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:14.788107 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:14.865292 [ 6609 ] {033c68c6-a7e6-456b-842f-6cda455596c4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'ceil'. Expected: A number to round, got: Array(Nothing): In scope SELECT ceiling([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ceiling([], []);) 2025.10.23 23:30:14.880570 [ 6609 ] {033c68c6-a7e6-456b-842f-6cda455596c4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'ceil'. Expected: A number to round, got: Array(Nothing): In scope SELECT ceiling([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:14.894996 [ 3283 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:14.905776 [ 4049 ] {2b51e2cc-d42e-4365-9023-7e9007d24355} 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.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:48248) (comment: 00005_filtering.sql) (in query: SELECT count() AS `count()` FROM `test`.`hits` AS `__table1` WHERE `__table1`.`AdvEngineID` != 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:30:14.913998 [ 4049 ] {2b51e2cc-d42e-4365-9023-7e9007d24355} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:30:14.953861 [ 6609 ] {2173cc96-c81c-4e04-932c-b889a1c2abfd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeDay'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeDay([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT changeDay([], []);) 2025.10.23 23:30:14.958362 [ 6609 ] {2173cc96-c81c-4e04-932c-b889a1c2abfd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeDay'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeDay([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:14.967192 [ 8268 ] {1eef35d1-6c6a-47c5-83d9-742b49fb9ab8} executeQuery: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 : While executing Remote. (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54610) (comment: 00005_filtering.sql) (in query: SELECT count() FROM test.hits WHERE AdvEngineID != 0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cfaa85e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278b7fb6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:30:14.976715 [ 8268 ] {1eef35d1-6c6a-47c5-83d9-742b49fb9ab8} TCPHandler: Code: 439. DB::Exception: Received from 127.0.0.6:9000. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). Stack trace: 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 : While executing Remote. (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::readException(DB::ReadBuffer&, String const&, bool) @ 0x000000001aebd7ae 3. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::Connection::receiveException() const @ 0x000000002cf0342a 4. ./build_docker/./src/Client/Connection.cpp:0: DB::Connection::receivePacket() @ 0x000000002cf13fce 5. ./build_docker/./src/Client/MultiplexedConnections.cpp:340: DB::MultiplexedConnections::receivePacketUnlocked(std::function) @ 0x000000002cfaa85e 6. ./build_docker/./src/QueryPipeline/RemoteQueryExecutorReadContext.cpp:0: DB::RemoteQueryExecutorReadContext::Task::run(std::function, std::function) @ 0x00000000278b7fb6 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b5dd6 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000278b53e4 9. ./contrib/boost/boost/context/fiber_ucontext.hpp:82: void boost::context::detail::fiber_entry_func>>(unsigned int, unsigned int) @ 0x00000000278b2d34 2025.10.23 23:30:15.014709 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:15.053928 [ 6609 ] {03496e34-1066-419c-b3d9-6d1a4e940c95} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeHour'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeHour([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT changeHour([], []);) 2025.10.23 23:30:15.068273 [ 4294 ] {a43f8d6d-3b73-4c92-8c5d-8f35bc3a72b2} executeQuery: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:50906). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:50906) (comment: 00005_filtering.sql) (in query: SELECT count() AS `count()` FROM `test`.`hits` AS `__table1` WHERE `__table1`.`AdvEngineID` != 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a85a0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:30:15.071586 [ 6609 ] {03496e34-1066-419c-b3d9-6d1a4e940c95} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeHour'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeHour([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:15.081548 [ 4294 ] {a43f8d6d-3b73-4c92-8c5d-8f35bc3a72b2} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:50906). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:15.086543 [ 4294 ] {a43f8d6d-3b73-4c92-8c5d-8f35bc3a72b2} TCPHandler: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.4]:9000 -> [::ffff:127.0.0.1]:50906). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendProgress() @ 0x000000002d1a8f52 6. ./build_docker/./src/Server/TCPHandler.cpp:1170: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a85a0 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:30:15.089599 [ 4294 ] {a43f8d6d-3b73-4c92-8c5d-8f35bc3a72b2} TCPHandler: Client has gone away. 2025.10.23 23:30:15.156260 [ 6609 ] {6960deef-0fca-4d45-8401-dc6416bf2064} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeMinute'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeMinute([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT changeMinute([], []);) 2025.10.23 23:30:15.167646 [ 6609 ] {6960deef-0fca-4d45-8401-dc6416bf2064} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeMinute'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeMinute([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:15.308623 [ 6609 ] {7a69cb87-eece-4f5e-9449-c661aa955677} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeMonth'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT changeMonth([], []);) 2025.10.23 23:30:15.316503 [ 6609 ] {7a69cb87-eece-4f5e-9449-c661aa955677} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeMonth'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:15.387322 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:15.423202 [ 6609 ] {cb95c984-7c05-4804-90fb-0bfc56eb3bca} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeSecond'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeSecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT changeSecond([], []);) 2025.10.23 23:30:15.436616 [ 6609 ] {cb95c984-7c05-4804-90fb-0bfc56eb3bca} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeSecond'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeSecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:15.621763 [ 6609 ] {31d56735-2a2b-4b3e-a903-1c9d9193e309} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeYear'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT changeYear([], []);) 2025.10.23 23:30:15.638445 [ 6609 ] {31d56735-2a2b-4b3e-a903-1c9d9193e309} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'date_or_datetime' to function 'changeYear'. Expected: Date or date with time, got: Array(Nothing): In scope SELECT changeYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:15.760784 [ 6609 ] {cee6ead7-f97a-4bd7-9e6e-735ece8731ce} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT char([], []);) 2025.10.23 23:30:15.765864 [ 6609 ] {cee6ead7-f97a-4bd7-9e6e-735ece8731ce} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function char, must be Int, UInt or Float number: In scope SELECT char([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:15.780670 [ 2787 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:15.825351 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:15.896976 [ 2788 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:15.957674 [ 6609 ] {ba26bb67-8312-4cbc-af71-44c79f238ee4} executeQuery: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT clamp([], []);) 2025.10.23 23:30:15.960419 [ 6609 ] {ba26bb67-8312-4cbc-af71-44c79f238ee4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function clamp doesn't match: passed 2, should be 3: In scope SELECT clamp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:16.420478 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:16.585622 [ 6609 ] {2a814311-0b7c-4f7f-ae2a-0a249d394ee1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT concatWithSeparator([], []);) 2025.10.23 23:30:16.596710 [ 6609 ] {2a814311-0b7c-4f7f-ae2a-0a249d394ee1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concatWithSeparator([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:16.682103 [ 6609 ] {edf42a33-23cd-4e67-9a24-ce7f51bee273} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT concatWithSeparatorAssumeInjective([], []);) 2025.10.23 23:30:16.690694 [ 6609 ] {edf42a33-23cd-4e67-9a24-ce7f51bee273} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparatorAssumeInjective: In scope SELECT concatWithSeparatorAssumeInjective([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:16.749280 [ 6609 ] {e49dace8-6eac-4b7a-a08b-97362b5c9381} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concat_ws([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT concat_ws([], []);) 2025.10.23 23:30:16.754385 [ 6609 ] {e49dace8-6eac-4b7a-a08b-97362b5c9381} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function concatWithSeparator: In scope SELECT concat_ws([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:16.783090 [ 2776 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:16.817290 [ 6609 ] {3109a626-f4c9-4863-944e-022dfcb3f90a} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT connectionId([], []);) 2025.10.23 23:30:16.821808 [ 6609 ] {3109a626-f4c9-4863-944e-022dfcb3f90a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connectionId([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:16.854349 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:16.872743 [ 6609 ] {1a7a8138-397f-45f4-8d72-606a2b6e3315} executeQuery: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT connection_id([], []);) 2025.10.23 23:30:16.877730 [ 6609 ] {1a7a8138-397f-45f4-8d72-606a2b6e3315} TCPHandler: Code: 42. DB::Exception: Number of arguments for function connectionId doesn't match: passed 2, should be 0: In scope SELECT connection_id([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:16.981525 [ 6609 ] {917460a0-7124-49f0-9daa-db541d918e33} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT contingency([], []);) 2025.10.23 23:30:16.985771 [ 2811 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:16.986125 [ 6609 ] {917460a0-7124-49f0-9daa-db541d918e33} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.10.23 23:30:17.096400 [ 6609 ] {fa29725d-217f-4ebc-bf7d-7c3f65a61347} executeQuery: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT convertCharset([], []);) 2025.10.23 23:30:17.107868 [ 6609 ] {fa29725d-217f-4ebc-bf7d-7c3f65a61347} TCPHandler: Code: 42. DB::Exception: Number of arguments for function convertCharset doesn't match: passed 2, should be 3: In scope SELECT convertCharset([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:17.193568 [ 6609 ] {44026556-f3a8-422d-809e-8ba3cc571c7c} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT corr([], []);) 2025.10.23 23:30:17.200637 [ 6609 ] {44026556-f3a8-422d-809e-8ba3cc571c7c} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function corr. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:17.245172 [ 4227 ] {89718193-9500-499e-adab-88ed42b64ca1} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.248992 [ 4227 ] {89718193-9500-499e-adab-88ed42b64ca1} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:17.326832 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (6 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:17.333850 [ 6609 ] {6782f764-90a1-4821-a12c-5fe7a94d7a5e} executeQuery: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT corrMatrix([], []);) 2025.10.23 23:30:17.336897 [ 6609 ] {6782f764-90a1-4821-a12c-5fe7a94d7a5e} TCPHandler: Code: 43. DB::Exception: Aggregate function corrMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:17.421751 [ 4415 ] {000fbb5e-4d42-4a47-81bc-e408c79ce39b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=21, jobs=21). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:54374) (comment: 00047_bar.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, count() AS `c`, bar(count(), 0, 523264) AS `bar(c, 0, 523264)` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC, `__table1`.`CounterID` ASC LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.424279 [ 8268 ] {22ccc6da-c965-4fc0-ab19-c9c850542b86} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=24). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39124) (comment: 00047_bar.sql) (in query: SELECT CounterID, count() AS c, bar(c, 0, 523264) FROM test.hits GROUP BY CounterID ORDER BY c DESC, CounterID ASC LIMIT 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.427307 [ 4415 ] {000fbb5e-4d42-4a47-81bc-e408c79ce39b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=21, jobs=21). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.431118 [ 4415 ] {000fbb5e-4d42-4a47-81bc-e408c79ce39b} TCPHandler: Client has gone away. 2025.10.23 23:30:17.437298 [ 8268 ] {22ccc6da-c965-4fc0-ab19-c9c850542b86} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=24, jobs=24). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.492430 [ 6609 ] {6f1ee145-cae0-493e-8929-a13fe2620567} executeQuery: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT corrStable([], []);) 2025.10.23 23:30:17.536267 [ 6609 ] {6f1ee145-cae0-493e-8929-a13fe2620567} TCPHandler: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.10.23 23:30:17.555055 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.608418 [ 6609 ] {b6afb2fc-e555-42bf-824a-99a53536449f} executeQuery: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cos([], []);) 2025.10.23 23:30:17.621117 [ 3677 ] {31a43e48-e545-470d-862c-d191bb5b177a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:47348). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:47348) (comment: 00047_bar.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, count() AS `c`, bar(count(), 0, 523264) AS `bar(c, 0, 523264)` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC, `__table1`.`CounterID` ASC LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1ad70b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a8129 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.633827 [ 6609 ] {b6afb2fc-e555-42bf-824a-99a53536449f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cos doesn't match: passed 2, should be 1: In scope SELECT cos([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:17.644233 [ 3677 ] {31a43e48-e545-470d-862c-d191bb5b177a} TCPHandler: Can't send logs to client: Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:47348). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:17.650647 [ 3677 ] {31a43e48-e545-470d-862c-d191bb5b177a} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.8]:9000 -> [::ffff:127.0.0.1]:47348). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1ad70b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a8129 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.654351 [ 3677 ] {31a43e48-e545-470d-862c-d191bb5b177a} TCPHandler: Client has gone away. 2025.10.23 23:30:17.703520 [ 6609 ] {a7474be7-77c6-4def-9fde-8e7c1c3d007e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cosh([], []);) 2025.10.23 23:30:17.723048 [ 6609 ] {a7474be7-77c6-4def-9fde-8e7c1c3d007e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cosh doesn't match: passed 2, should be 1: In scope SELECT cosh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:17.723677 [ 4203 ] {05943257-e240-466f-aa31-82a243abcc14} executeQuery: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:60302): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:60302) (comment: 00047_bar.sql) (in query: SELECT `__table1`.`CounterID` AS `CounterID`, count() AS `c`, bar(count(), 0, 523264) AS `bar(c, 0, 523264)` FROM `test`.`hits` AS `__table1` GROUP BY `__table1`.`CounterID` ORDER BY count() DESC, `__table1`.`CounterID` ASC LIMIT _CAST(100, 'UInt64')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000002d1b55b7 6. ./build_docker/./src/Server/TCPHandler.cpp:561: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002d1c958e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:34: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>, std::optional (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002c83a9b9 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:81: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x000000002c834436 9. ./contrib/llvm-project/libcxx/include/deque:1198: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df06b7c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.735071 [ 4203 ] {05943257-e240-466f-aa31-82a243abcc14} 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]:60302). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:17.744840 [ 4203 ] {05943257-e240-466f-aa31-82a243abcc14} TCPHandler: Code: 210. DB::Exception: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:9000 -> [::ffff:127.0.0.1]:60302): While executing MergeTreeSelect(pool: ReadPoolParallelReplicas, algorithm: Thread). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendMergeTreeReadTaskRequestAssumeLocked(DB::ParallelReadRequest) @ 0x000000002d1b55b7 6. ./build_docker/./src/Server/TCPHandler.cpp:561: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002d1c958e 7. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:34: std::optional std::__function::__policy_invoker (DB::ParallelReadRequest)>::__call_impl (DB::ParallelReadRequest)>>, std::optional (DB::ParallelReadRequest)>>(std::__function::__policy_storage const*, DB::ParallelReadRequest&&) @ 0x000000002c83a9b9 8. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:81: DB::ParallelReadingExtension::sendReadRequest(DB::CoordinationMode, unsigned long, DB::RangesInDataPartsDescription const&) const @ 0x000000002c834436 9. ./contrib/llvm-project/libcxx/include/deque:1198: DB::MergeTreeReadPoolParallelReplicas::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df06b7c 10. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 11. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 12. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 15. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 17. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.748077 [ 4203 ] {05943257-e240-466f-aa31-82a243abcc14} TCPHandler: Client has gone away. 2025.10.23 23:30:17.785471 [ 2821 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:17.815288 [ 6609 ] {631ff157-7787-4f29-a734-0254c629f53e} executeQuery: Code: 43. DB::Exception: Arguments of function arrayCosineDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT cosineDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cosineDistance([], []);) 2025.10.23 23:30:17.843683 [ 6609 ] {631ff157-7787-4f29-a734-0254c629f53e} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayCosineDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT cosineDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:17.904185 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:17.905608 [ 6609 ] {ace5ad3f-3ec8-4f81-8ebc-4d4396a7e226} executeQuery: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT count([], []);) 2025.10.23 23:30:17.915041 [ 6609 ] {ace5ad3f-3ec8-4f81-8ebc-4d4396a7e226} TCPHandler: Code: 42. DB::Exception: Aggregate function count requires zero or one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:17.990891 [ 2829 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:18.012367 [ 6609 ] {74b39558-87c4-41c9-882e-dd292d1452ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT countDigits([], []);) 2025.10.23 23:30:18.017029 [ 6609 ] {74b39558-87c4-41c9-882e-dd292d1452ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function countDigits doesn't match: passed 2, should be 1: In scope SELECT countDigits([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:18.262421 [ 3495 ] {676b15bb-58be-44c5-bd89-6d55542cbf9c} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:18.268297 [ 3495 ] {676b15bb-58be-44c5-bd89-6d55542cbf9c} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:18.281035 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (6 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:18.306104 [ 6609 ] {2370eca9-61c7-4646-8af4-de3b8c64f60a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'countMatches'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT countMatches([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT countMatches([], []);) 2025.10.23 23:30:18.311078 [ 6609 ] {2370eca9-61c7-4646-8af4-de3b8c64f60a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'countMatches'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT countMatches([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:18.354626 [ 4049 ] {0faf8849-d373-43c3-b301-f477bb1169f9} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT UserID, CAST(EventTime, 'DateTime(\'Asia/Dubai\')'), pp.Key1, pp.Key2, ParsedParams.Key1 FROM test.hits ARRAY JOIN ParsedParams AS pp WHERE CounterID = 1704509 ORDER BY UserID ASC, EventTime ASC, pp.Key1 ASC, pp.Key2 ASC LIMIT 100. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39160) (comment: 00075_left_array_join.sql) (in query: SELECT UserID, EventTime::DateTime('Asia/Dubai'), pp.Key1, pp.Key2, ParsedParams.Key1 FROM test.hits ARRAY JOIN ParsedParams AS pp WHERE CounterID = 1704509 ORDER BY UserID, EventTime, pp.Key1, pp.Key2 LIMIT 100;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:30:18.375280 [ 4049 ] {0faf8849-d373-43c3-b301-f477bb1169f9} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT UserID, CAST(EventTime, 'DateTime(\'Asia/Dubai\')'), pp.Key1, pp.Key2, ParsedParams.Key1 FROM test.hits ARRAY JOIN ParsedParams AS pp WHERE CounterID = 1704509 ORDER BY UserID ASC, EventTime ASC, pp.Key1 ASC, pp.Key2 ASC LIMIT 100. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:30:18.439182 [ 6609 ] {ddb9b00d-eba4-44d2-9e09-de7bc6afd610} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'countMatchesCaseInsensitive'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT countMatchesCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT countMatchesCaseInsensitive([], []);) 2025.10.23 23:30:18.449421 [ 6609 ] {ddb9b00d-eba4-44d2-9e09-de7bc6afd610} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'countMatchesCaseInsensitive'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT countMatchesCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:18.557841 [ 6609 ] {30e44aa2-7a94-496d-8661-2eaa13188c64} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstrings: In scope SELECT countSubstrings([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT countSubstrings([], []);) 2025.10.23 23:30:18.563493 [ 6609 ] {30e44aa2-7a94-496d-8661-2eaa13188c64} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstrings: In scope SELECT countSubstrings([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:18.593877 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:18.707479 [ 6609 ] {c864408b-3981-4ec5-bca0-ab47cf54ecea} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstringsCaseInsensitive: In scope SELECT countSubstringsCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT countSubstringsCaseInsensitive([], []);) 2025.10.23 23:30:18.726659 [ 6609 ] {c864408b-3981-4ec5-bca0-ab47cf54ecea} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstringsCaseInsensitive: In scope SELECT countSubstringsCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:18.787683 [ 2842 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:18.889348 [ 6609 ] {aa7189b8-51ec-4583-939f-583752b63c95} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstringsCaseInsensitiveUTF8: In scope SELECT countSubstringsCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT countSubstringsCaseInsensitiveUTF8([], []);) 2025.10.23 23:30:18.893075 [ 6609 ] {aa7189b8-51ec-4583-939f-583752b63c95} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function countSubstringsCaseInsensitiveUTF8: In scope SELECT countSubstringsCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:18.928839 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:18.971732 [ 6609 ] {9cd8ae4a-c4f9-4911-b8e9-a318c6d4b2e4} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT covarPop([], []);) 2025.10.23 23:30:18.976203 [ 6609 ] {9cd8ae4a-c4f9-4911-b8e9-a318c6d4b2e4} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function covarPop. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:18.993310 [ 2843 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:19.105220 [ 6609 ] {5e1d8101-88af-45db-aed4-dd30898ba6ec} executeQuery: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT covarPopMatrix([], []);) 2025.10.23 23:30:19.117434 [ 6609 ] {5e1d8101-88af-45db-aed4-dd30898ba6ec} TCPHandler: Code: 43. DB::Exception: Aggregate function covarPopMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:19.231658 [ 6609 ] {d5b1fbdd-01bc-4954-94d8-d08af230147d} executeQuery: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT covarPopStable([], []);) 2025.10.23 23:30:19.237779 [ 6609 ] {d5b1fbdd-01bc-4954-94d8-d08af230147d} TCPHandler: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.10.23 23:30:19.293560 [ 6609 ] {6c42fd14-62c0-484b-a596-c589bc46adb8} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT covarSamp([], []);) 2025.10.23 23:30:19.300749 [ 6609 ] {6c42fd14-62c0-484b-a596-c589bc46adb8} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments for aggregate function covarSamp. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:19.476332 [ 6609 ] {0d93268c-1de8-446f-a377-c0ea761a46cd} executeQuery: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT covarSampMatrix([], []);) 2025.10.23 23:30:19.480123 [ 6609 ] {0d93268c-1de8-446f-a377-c0ea761a46cd} TCPHandler: Code: 43. DB::Exception: Aggregate function covarSampMatrix only supports numerical types. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:19.616387 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:19.641131 [ 6609 ] {b3bb3ce6-c38b-4ac2-a2ea-766eaa2b89af} executeQuery: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT covarSampStable([], []);) 2025.10.23 23:30:19.647669 [ 6609 ] {b3bb3ce6-c38b-4ac2-a2ea-766eaa2b89af} TCPHandler: Code: 48. DB::Exception: Method getFloat64 is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.10.23 23:30:19.770730 [ 6609 ] {9e5275b2-8211-4887-8551-b2ca289d9d48} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cramersV([], []);) 2025.10.23 23:30:19.777870 [ 6609 ] {9e5275b2-8211-4887-8551-b2ca289d9d48} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.10.23 23:30:19.790496 [ 2863 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:19.934769 [ 6609 ] {c7aa5967-a4ab-4d1a-ad43-46527da9108d} executeQuery: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cramersVBiasCorrected([], []);) 2025.10.23 23:30:19.939528 [ 6609 ] {c7aa5967-a4ab-4d1a-ad43-46527da9108d} TCPHandler: Code: 48. DB::Exception: Method getDataAt is not supported for Array(Nothing): While executing AggregatingTransform. (NOT_IMPLEMENTED) 2025.10.23 23:30:19.992807 [ 6609 ] {3604aefb-efd2-4d15-a300-b567321d3854} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT curdate([], []);) 2025.10.23 23:30:19.996315 [ 6609 ] {3604aefb-efd2-4d15-a300-b567321d3854} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT curdate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.000604 [ 2866 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:20.054831 [ 6609 ] {37754146-9a7e-4d15-ba06-6654e6ab1235} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT currentDatabase([], []);) 2025.10.23 23:30:20.070763 [ 6609 ] {37754146-9a7e-4d15-ba06-6654e6ab1235} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT currentDatabase([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.074395 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:20.141197 [ 6609 ] {aa1e62f7-cf9c-42e4-ac61-0f893e6bf32a} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT currentProfiles([], []);) 2025.10.23 23:30:20.148667 [ 6609 ] {aa1e62f7-cf9c-42e4-ac61-0f893e6bf32a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentProfiles doesn't match: passed 2, should be 0: In scope SELECT currentProfiles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.210645 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:20.261849 [ 6609 ] {439080d2-fdec-49f1-ba2b-2b39e0236420} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT currentRoles([], []);) 2025.10.23 23:30:20.272102 [ 6609 ] {439080d2-fdec-49f1-ba2b-2b39e0236420} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentRoles doesn't match: passed 2, should be 0: In scope SELECT currentRoles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.370843 [ 6609 ] {b698de3d-052e-48b7-b29a-d2c97b65717f} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT currentSchemas([], []);) 2025.10.23 23:30:20.378601 [ 6609 ] {b698de3d-052e-48b7-b29a-d2c97b65717f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT currentSchemas([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.509079 [ 6609 ] {9461b819-905e-4dbd-a9d7-b846ba9a94e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT currentUser([], []);) 2025.10.23 23:30:20.518673 [ 6609 ] {9461b819-905e-4dbd-a9d7-b846ba9a94e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT currentUser([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.634410 [ 6609 ] {8e986db0-504c-4f22-8591-e2591ccf1d64} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT current_database([], []);) 2025.10.23 23:30:20.641577 [ 6609 ] {8e986db0-504c-4f22-8591-e2591ccf1d64} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentDatabase doesn't match: passed 2, should be 0: In scope SELECT current_database([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.641637 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:20.764732 [ 6609 ] {3fc12bf8-144a-4b56-9671-63d00374abc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT current_date([], []);) 2025.10.23 23:30:20.785947 [ 6609 ] {3fc12bf8-144a-4b56-9671-63d00374abc3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT current_date([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.825300 [ 2880 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:20.893068 [ 6609 ] {14a8e91a-1edb-4124-ac62-f22a0ebc70e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT current_schemas([], []);) 2025.10.23 23:30:20.897973 [ 6609 ] {14a8e91a-1edb-4124-ac62-f22a0ebc70e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentSchemas doesn't match: passed 2, should be 1: In scope SELECT current_schemas([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:20.980797 [ 6609 ] {0a688e9f-e002-40f9-be30-ea02d5c953e6} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT current_timestamp([], []);) 2025.10.23 23:30:20.992182 [ 6609 ] {0a688e9f-e002-40f9-be30-ea02d5c953e6} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT current_timestamp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:21.013347 [ 2883 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:21.079192 [ 6609 ] {2a20f4f7-5f84-4ada-a340-8fe235768256} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT current_user([], []);) 2025.10.23 23:30:21.085394 [ 6609 ] {2a20f4f7-5f84-4ada-a340-8fe235768256} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT current_user([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:21.146054 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:21.150687 [ 6609 ] {2479c288-1502-4ffd-b955-c75d8aa81c69} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutFragment([], []);) 2025.10.23 23:30:21.154763 [ 6609 ] {2479c288-1502-4ffd-b955-c75d8aa81c69} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutFragment doesn't match: passed 2, should be 1: In scope SELECT cutFragment([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:21.211624 [ 6609 ] {73947547-2945-4be1-9bd3-38e17fdc39fe} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutIPv6([], []);) 2025.10.23 23:30:21.220978 [ 6609 ] {73947547-2945-4be1-9bd3-38e17fdc39fe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutIPv6 doesn't match: passed 2, should be 3: In scope SELECT cutIPv6([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:21.346583 [ 6609 ] {53bfd9bd-ac60-47a3-b133-b6aaa8fe267c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutQueryString([], []);) 2025.10.23 23:30:21.352174 [ 6609 ] {53bfd9bd-ac60-47a3-b133-b6aaa8fe267c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryString doesn't match: passed 2, should be 1: In scope SELECT cutQueryString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:21.427408 [ 6609 ] {5352694c-6e4e-4296-a94f-95e9d026535e} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutQueryStringAndFragment([], []);) 2025.10.23 23:30:21.441955 [ 6609 ] {5352694c-6e4e-4296-a94f-95e9d026535e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutQueryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT cutQueryStringAndFragment([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:21.555076 [ 6609 ] {20524c48-9c3c-446b-92eb-da70aeb123be} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutToFirstSignificantSubdomain([], []);) 2025.10.23 23:30:21.577832 [ 6609 ] {20524c48-9c3c-446b-92eb-da70aeb123be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomain([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:21.641112 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:21.654789 [ 6609 ] {fa740107-682a-4995-bf70-cd41074be972} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function cutToFirstSignificantSubdomainCustom. Must be String.: In scope SELECT cutToFirstSignificantSubdomainCustom([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutToFirstSignificantSubdomainCustom([], []);) 2025.10.23 23:30:21.660937 [ 6609 ] {fa740107-682a-4995-bf70-cd41074be972} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function cutToFirstSignificantSubdomainCustom. Must be String.: In scope SELECT cutToFirstSignificantSubdomainCustom([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:21.748828 [ 6609 ] {cc3c9aa9-d945-49be-bc15-97f757626694} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function cutToFirstSignificantSubdomainCustomRFC. Must be String.: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomRFC([], []);) 2025.10.23 23:30:21.753978 [ 6609 ] {cc3c9aa9-d945-49be-bc15-97f757626694} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function cutToFirstSignificantSubdomainCustomRFC. Must be String.: In scope SELECT cutToFirstSignificantSubdomainCustomRFC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:21.808128 [ 6609 ] {1b882e7d-19ed-4456-9af7-d30dcb0e6170} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function cutToFirstSignificantSubdomainCustomWithWWW. Must be String.: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWW([], []);) 2025.10.23 23:30:21.813594 [ 6609 ] {1b882e7d-19ed-4456-9af7-d30dcb0e6170} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function cutToFirstSignificantSubdomainCustomWithWWW. Must be String.: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWW([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:21.827396 [ 2899 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:21.922618 [ 6609 ] {6e5ba975-a421-4776-bb33-8f4d2be280ac} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function cutToFirstSignificantSubdomainCustomWithWWWRFC. Must be String.: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([], []);) 2025.10.23 23:30:21.929616 [ 6609 ] {6e5ba975-a421-4776-bb33-8f4d2be280ac} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function cutToFirstSignificantSubdomainCustomWithWWWRFC. Must be String.: In scope SELECT cutToFirstSignificantSubdomainCustomWithWWWRFC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:22.012866 [ 6609 ] {a5517a74-30fc-4cca-a368-8d0935cd9c97} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutToFirstSignificantSubdomainRFC([], []);) 2025.10.23 23:30:22.015589 [ 2900 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:22.018539 [ 6609 ] {a5517a74-30fc-4cca-a368-8d0935cd9c97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:22.101598 [ 6609 ] {4584efe3-4554-4883-bba8-2f7a76f72c47} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWW([], []);) 2025.10.23 23:30:22.107088 [ 6609 ] {4584efe3-4554-4883-bba8-2f7a76f72c47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWW doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWW([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:22.205200 [ 6609 ] {c61c16e0-286f-4578-a09c-731f5647a11c} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutToFirstSignificantSubdomainWithWWWRFC([], []);) 2025.10.23 23:30:22.213132 [ 6609 ] {c61c16e0-286f-4578-a09c-731f5647a11c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutToFirstSignificantSubdomainWithWWWRFC doesn't match: passed 2, should be 1: In scope SELECT cutToFirstSignificantSubdomainWithWWWRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:22.257437 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:22.273362 [ 6609 ] {f3c89bea-36e5-4109-9c9d-d95dd79caad3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutURLParameter: In scope SELECT cutURLParameter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutURLParameter([], []);) 2025.10.23 23:30:22.283466 [ 6609 ] {f3c89bea-36e5-4109-9c9d-d95dd79caad3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function cutURLParameter: In scope SELECT cutURLParameter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:22.412464 [ 6609 ] {e9699e9e-d87a-45d5-9a45-eac22633b825} executeQuery: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT cutWWW([], []);) 2025.10.23 23:30:22.420414 [ 6609 ] {e9699e9e-d87a-45d5-9a45-eac22633b825} TCPHandler: Code: 42. DB::Exception: Number of arguments for function cutWWW doesn't match: passed 2, should be 1: In scope SELECT cutWWW([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:22.672051 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:22.705095 [ 6609 ] {2529f75e-cb7f-4ff4-b627-c02db84a6b26} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function damerauLevenshteinDistance: In scope SELECT damerauLevenshteinDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT damerauLevenshteinDistance([], []);) 2025.10.23 23:30:22.709320 [ 6609 ] {2529f75e-cb7f-4ff4-b627-c02db84a6b26} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function damerauLevenshteinDistance: In scope SELECT damerauLevenshteinDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:22.781255 [ 6609 ] {5a9de0a8-0aff-4e4a-9518-e88b509589e2} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dateDiff([], []);) 2025.10.23 23:30:22.786178 [ 6609 ] {5a9de0a8-0aff-4e4a-9518-e88b509589e2} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:22.812277 [ 4227 ] {1cc9522e-3316-4b3f-932c-9ec479723777} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:22.814848 [ 4227 ] {1cc9522e-3316-4b3f-932c-9ec479723777} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:22.824639 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (7 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:22.829460 [ 2913 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:22.841509 [ 6609 ] {09e8b30b-dc50-4639-8b44-43a137595e6d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1 argument of function dateName. Must be string: In scope SELECT dateName([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dateName([], []);) 2025.10.23 23:30:22.847154 [ 6609 ] {09e8b30b-dc50-4639-8b44-43a137595e6d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1 argument of function dateName. Must be string: In scope SELECT dateName([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:22.905175 [ 6609 ] {8da693b3-5984-4c95-aa7f-fe6db738e648} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dateTime64ToSnowflake([], []);) 2025.10.23 23:30:22.915517 [ 6609 ] {8da693b3-5984-4c95-aa7f-fe6db738e648} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTime64ToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTime64ToSnowflake([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:23.015582 [ 6609 ] {2eca7828-b750-428b-ae31-dbab85f26bfa} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflakeID'. Expected: DateTime64, got: Array(Nothing): In scope SELECT dateTime64ToSnowflakeID([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dateTime64ToSnowflakeID([], []);) 2025.10.23 23:30:23.017443 [ 2920 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:23.025075 [ 6609 ] {2eca7828-b750-428b-ae31-dbab85f26bfa} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTime64ToSnowflakeID'. Expected: DateTime64, got: Array(Nothing): In scope SELECT dateTime64ToSnowflakeID([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:23.119845 [ 6609 ] {a5855ed9-6fa1-4494-9e58-f2a13621f16a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dateTimeToSnowflake([], []);) 2025.10.23 23:30:23.134541 [ 6609 ] {a5855ed9-6fa1-4494-9e58-f2a13621f16a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dateTimeToSnowflake doesn't match: passed 2, should be 1: In scope SELECT dateTimeToSnowflake([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:23.250158 [ 6609 ] {c9949d15-b9e9-4a16-8762-044e6f0aca76} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflakeID'. Expected: DateTime, got: Array(Nothing): In scope SELECT dateTimeToSnowflakeID([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dateTimeToSnowflakeID([], []);) 2025.10.23 23:30:23.255600 [ 6609 ] {c9949d15-b9e9-4a16-8762-044e6f0aca76} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'dateTimeToSnowflakeID'. Expected: DateTime, got: Array(Nothing): In scope SELECT dateTimeToSnowflakeID([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:23.353831 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:23.370594 [ 6609 ] {3c559769-1085-45ae-941d-ee0ef367280a} executeQuery: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT dateTrunc([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dateTrunc([], []);) 2025.10.23 23:30:23.378190 [ 6609 ] {3c559769-1085-45ae-941d-ee0ef367280a} TCPHandler: Code: 43. DB::Exception: First argument for function dateTrunc must be constant string: name of datepart: In scope SELECT dateTrunc([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:23.511632 [ 6609 ] {1d9c4005-ffd9-4c53-994f-9c3710791dfb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT date_diff([], []);) 2025.10.23 23:30:23.516913 [ 6609 ] {1d9c4005-ffd9-4c53-994f-9c3710791dfb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:23.604011 [ 6609 ] {f1b4b873-abe1-4719-935f-6e2fa2c653be} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT decodeHTMLComponent([], []);) 2025.10.23 23:30:23.613857 [ 6609 ] {f1b4b873-abe1-4719-935f-6e2fa2c653be} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeHTMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeHTMLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:23.707628 [ 6609 ] {4e533f46-7a17-495a-a174-91326830046c} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT decodeURLComponent([], []);) 2025.10.23 23:30:23.713433 [ 6609 ] {4e533f46-7a17-495a-a174-91326830046c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:23.781888 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:23.831798 [ 2931 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:23.837791 [ 6609 ] {59952c3e-d674-4db9-b656-75801c9742d1} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT decodeURLFormComponent([], []);) 2025.10.23 23:30:23.850140 [ 6609 ] {59952c3e-d674-4db9-b656-75801c9742d1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT decodeURLFormComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:23.950800 [ 6609 ] {1390175b-ba45-4ccd-9f36-a2d525f8b426} executeQuery: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT decodeXMLComponent([], []);) 2025.10.23 23:30:23.960043 [ 6609 ] {1390175b-ba45-4ccd-9f36-a2d525f8b426} TCPHandler: Code: 42. DB::Exception: Number of arguments for function decodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT decodeXMLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:24.019400 [ 2933 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:24.046230 [ 3495 ] {5a9653bc-bebf-4927-85b6-a3acee77bd4d} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:24.050482 [ 3495 ] {5a9653bc-bebf-4927-85b6-a3acee77bd4d} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:24.060526 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (7 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:24.062925 [ 6609 ] {9bec9ffd-cebe-4bc2-99e3-14bd3410eaf4} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT decrypt([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT decrypt([], '[HIDDEN]')) 2025.10.23 23:30:24.069331 [ 6609 ] {9bec9ffd-cebe-4bc2-99e3-14bd3410eaf4} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'decrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT decrypt([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:24.152206 [ 6609 ] {366a6584-6d50-4f99-933d-e3d53e9c4466} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT defaultProfiles([], []);) 2025.10.23 23:30:24.157891 [ 6609 ] {366a6584-6d50-4f99-933d-e3d53e9c4466} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultProfiles doesn't match: passed 2, should be 0: In scope SELECT defaultProfiles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:24.290830 [ 6609 ] {b29e6ef6-c4da-4de2-867c-a4ddc9ce2c85} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT defaultRoles([], []);) 2025.10.23 23:30:24.302568 [ 6609 ] {b29e6ef6-c4da-4de2-867c-a4ddc9ce2c85} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultRoles doesn't match: passed 2, should be 0: In scope SELECT defaultRoles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:24.425929 [ 6609 ] {37ec4d64-d895-4571-93a8-659fbe55f80f} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT defaultValueOfArgumentType([], []);) 2025.10.23 23:30:24.437419 [ 6609 ] {37ec4d64-d895-4571-93a8-659fbe55f80f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfArgumentType doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfArgumentType([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:24.443943 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:24.568889 [ 6609 ] {33fc5eb4-e384-44db-8968-f17a71e83699} executeQuery: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT defaultValueOfTypeName([], []);) 2025.10.23 23:30:24.580144 [ 6609 ] {33fc5eb4-e384-44db-8968-f17a71e83699} TCPHandler: Code: 42. DB::Exception: Number of arguments for function defaultValueOfTypeName doesn't match: passed 2, should be 1: In scope SELECT defaultValueOfTypeName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:24.684330 [ 6609 ] {9f9322ed-7ec2-4f05-828f-3d35aadf6850} executeQuery: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT degrees([], []);) 2025.10.23 23:30:24.705401 [ 6609 ] {9f9322ed-7ec2-4f05-828f-3d35aadf6850} TCPHandler: Code: 42. DB::Exception: Number of arguments for function degrees doesn't match: passed 2, should be 1: In scope SELECT degrees([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:24.804428 [ 6609 ] {3f499925-ae7e-44c2-a5af-71d74247e8b6} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT deltaSum([], []);) 2025.10.23 23:30:24.810129 [ 6609 ] {3f499925-ae7e-44c2-a5af-71d74247e8b6} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments for aggregate function deltaSum. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:24.834304 [ 2952 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:24.858629 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:24.873960 [ 6609 ] {0fa50ef8-d04d-413e-871c-083e54883193} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT deltaSumTimestamp([], []);) 2025.10.23 23:30:24.883276 [ 6609 ] {0fa50ef8-d04d-413e-871c-083e54883193} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function deltaSumTimestamp, must be Int, Float, Date, DateTime. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:24.986395 [ 6609 ] {b70d2e69-fc36-4504-8d87-42c7867587e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT demangle([], []);) 2025.10.23 23:30:24.992668 [ 6609 ] {b70d2e69-fc36-4504-8d87-42c7867587e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function demangle doesn't match: passed 2, should be 1: In scope SELECT demangle([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:25.021802 [ 2959 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:25.103369 [ 6609 ] {f17039d8-57c9-4038-927b-af9781946072} 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.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT denseRank([], []);) 2025.10.23 23:30:25.107318 [ 6609 ] {f17039d8-57c9-4038-927b-af9781946072} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:30:25.276995 [ 6609 ] {95a2e77b-9f6e-4bba-9b7b-9c7f9f1e49eb} executeQuery: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dense_rank([], []);) 2025.10.23 23:30:25.279314 [ 6609 ] {95a2e77b-9f6e-4bba-9b7b-9c7f9f1e49eb} TCPHandler: Code: 36. DB::Exception: The function 'denseRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:30:25.320942 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:25.360025 [ 6609 ] {1c84e1bf-b3b9-4a44-a7d6-4e6b88167f9a} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT detectCharset([], []);) 2025.10.23 23:30:25.366830 [ 6609 ] {1c84e1bf-b3b9-4a44-a7d6-4e6b88167f9a} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectCharset' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:30:25.460353 [ 6609 ] {a0327973-0c08-47fa-93a0-f00f2859fdfc} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT detectLanguage([], []);) 2025.10.23 23:30:25.465524 [ 6609 ] {a0327973-0c08-47fa-93a0-f00f2859fdfc} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:30:25.516488 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:25.584914 [ 6609 ] {93581491-cc02-4772-8dba-d15b1fe2a7c3} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT detectLanguageMixed([], []);) 2025.10.23 23:30:25.609214 [ 6609 ] {93581491-cc02-4772-8dba-d15b1fe2a7c3} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageMixed' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:30:25.782531 [ 6609 ] {f4cdc2c9-63e5-450a-b05a-77c90ee4e674} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT detectLanguageUnknown([], []);) 2025.10.23 23:30:25.794679 [ 6609 ] {f4cdc2c9-63e5-450a-b05a-77c90ee4e674} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectLanguageUnknown' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:30:25.840469 [ 2968 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:25.893894 [ 6609 ] {480db1f1-73d6-47db-b557-872d1b81dc00} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT detectProgrammingLanguage([], []);) 2025.10.23 23:30:25.897730 [ 6609 ] {480db1f1-73d6-47db-b557-872d1b81dc00} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectProgrammingLanguage' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:30:25.950579 [ 6609 ] {025ea62b-b5af-4538-8bd2-e23da1b4c5cd} executeQuery: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT detectTonality([], []);) 2025.10.23 23:30:25.953751 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:25.955769 [ 6609 ] {025ea62b-b5af-4538-8bd2-e23da1b4c5cd} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'detectTonality' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:30:26.024231 [ 2964 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:26.108649 [ 6609 ] {0c400f6a-5c92-43c7-bbe6-78f1a8e4214e} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGet([], []);) 2025.10.23 23:30:26.120448 [ 6609 ] {0c400f6a-5c92-43c7-bbe6-78f1a8e4214e} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGet([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:26.264012 [ 6609 ] {2d5499a5-833c-4573-8766-93b39fd85fb6} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetAll([], []);) 2025.10.23 23:30:26.363491 [ 6609 ] {2d5499a5-833c-4573-8766-93b39fd85fb6} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetAll: In scope SELECT dictGetAll([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:26.427486 [ 6609 ] {ceb8137f-81ed-4969-863b-fe9c80185ae8} executeQuery: Code: 43. DB::Exception: Illegal type of first argument of function dictGetChildren. Expected const String. Actual type Array(Nothing): In scope SELECT dictGetChildren([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetChildren([], []);) 2025.10.23 23:30:26.435831 [ 6609 ] {ceb8137f-81ed-4969-863b-fe9c80185ae8} TCPHandler: Code: 43. DB::Exception: Illegal type of first argument of function dictGetChildren. Expected const String. Actual type Array(Nothing): In scope SELECT dictGetChildren([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:26.499003 [ 6609 ] {1c3a8ec1-231c-4675-abf3-35d9ad1d0b9c} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetDate([], []);) 2025.10.23 23:30:26.502018 [ 6609 ] {1c3a8ec1-231c-4675-abf3-35d9ad1d0b9c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDate doesn't match: the function requires more arguments: In scope SELECT dictGetDate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:26.561175 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:26.565809 [ 6609 ] {2b97f06d-5b64-4744-a4fa-edd0c308c9bd} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetDateOrDefault([], []);) 2025.10.23 23:30:26.579099 [ 6609 ] {2b97f06d-5b64-4744-a4fa-edd0c308c9bd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:26.750958 [ 6609 ] {3934b3f1-1c19-4379-b9e1-1a749064ea20} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetDateTime([], []);) 2025.10.23 23:30:26.769130 [ 6609 ] {3934b3f1-1c19-4379-b9e1-1a749064ea20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTime doesn't match: the function requires more arguments: In scope SELECT dictGetDateTime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:26.842818 [ 2979 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:26.878797 [ 6609 ] {674c2407-d237-45ba-8f01-767409b10dbd} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetDateTimeOrDefault([], []);) 2025.10.23 23:30:26.889451 [ 6609 ] {674c2407-d237-45ba-8f01-767409b10dbd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetDateTimeOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetDateTimeOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:26.975226 [ 6609 ] {273a0e5a-ccd5-4dbe-b09b-b095011443e8} executeQuery: Code: 43. DB::Exception: Illegal type of first argument of function dictGetDescendants. Expected const String. Actual type Array(Nothing): In scope SELECT dictGetDescendants([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetDescendants([], []);) 2025.10.23 23:30:26.980243 [ 6609 ] {273a0e5a-ccd5-4dbe-b09b-b095011443e8} TCPHandler: Code: 43. DB::Exception: Illegal type of first argument of function dictGetDescendants. Expected const String. Actual type Array(Nothing): In scope SELECT dictGetDescendants([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:26.984430 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:27.055022 [ 6609 ] {12096be4-3d0f-45a9-8ac5-7751ba4ca4ce} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetFloat32([], []);) 2025.10.23 23:30:27.064681 [ 2984 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:27.077247 [ 6609 ] {12096be4-3d0f-45a9-8ac5-7751ba4ca4ce} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:27.133556 [ 6609 ] {fcc00c99-3aa8-4f73-9728-87d1252af406} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetFloat32OrDefault([], []);) 2025.10.23 23:30:27.137568 [ 6609 ] {fcc00c99-3aa8-4f73-9728-87d1252af406} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat32OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:27.200839 [ 6609 ] {b71a52aa-3776-4646-85f4-a64b75112ee9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetFloat64([], []);) 2025.10.23 23:30:27.218353 [ 6609 ] {b71a52aa-3776-4646-85f4-a64b75112ee9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64 doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:27.319890 [ 6609 ] {00172b50-c48b-42aa-976f-64cce123bdb4} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetFloat64OrDefault([], []);) 2025.10.23 23:30:27.328673 [ 6609 ] {00172b50-c48b-42aa-976f-64cce123bdb4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetFloat64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetFloat64OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:27.433259 [ 6609 ] {7435c896-f310-4b8d-ad64-3468f4716405} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetHierarchy, expected a const string.: In scope SELECT dictGetHierarchy([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetHierarchy([], []);) 2025.10.23 23:30:27.456891 [ 6609 ] {7435c896-f310-4b8d-ad64-3468f4716405} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictGetHierarchy, expected a const string.: In scope SELECT dictGetHierarchy([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:27.507341 [ 6609 ] {d04269c6-6b25-406a-8c0f-7553682bea4a} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetIPv4([], []);) 2025.10.23 23:30:27.511659 [ 6609 ] {d04269c6-6b25-406a-8c0f-7553682bea4a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:27.602461 [ 6609 ] {3310bfb5-eff3-43f0-9b87-1001b1f9a0b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetIPv4OrDefault([], []);) 2025.10.23 23:30:27.608489 [ 6609 ] {3310bfb5-eff3-43f0-9b87-1001b1f9a0b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv4OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv4OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:27.635690 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:27.717457 [ 6609 ] {2c7d6bd1-ddb8-4170-bca5-73886472571b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetIPv6([], []);) 2025.10.23 23:30:27.739207 [ 6609 ] {2c7d6bd1-ddb8-4170-bca5-73886472571b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6 doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:27.844857 [ 2999 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:27.863106 [ 6609 ] {3adb834d-8de6-4505-91ba-4f5c36c02b3d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetIPv6OrDefault([], []);) 2025.10.23 23:30:27.875034 [ 6609 ] {3adb834d-8de6-4505-91ba-4f5c36c02b3d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetIPv6OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetIPv6OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:27.951113 [ 6609 ] {9e45170c-0ddd-42f9-aaa9-e43ec444090b} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetInt16([], []);) 2025.10.23 23:30:27.956197 [ 6609 ] {9e45170c-0ddd-42f9-aaa9-e43ec444090b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:28.015178 [ 6609 ] {38b0fe1d-a5a6-436f-8336-3032472ae879} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetInt16OrDefault([], []);) 2025.10.23 23:30:28.016743 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:28.019199 [ 6609 ] {38b0fe1d-a5a6-436f-8336-3032472ae879} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt16OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:28.068029 [ 3004 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:28.212284 [ 6609 ] {087ec95e-5377-457f-9a05-0cedcdaecfed} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetInt32([], []);) 2025.10.23 23:30:28.218365 [ 6609 ] {087ec95e-5377-457f-9a05-0cedcdaecfed} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:28.274111 [ 6609 ] {edaad578-c13f-43c3-8228-83ed2d9c0472} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetInt32OrDefault([], []);) 2025.10.23 23:30:28.280048 [ 6609 ] {edaad578-c13f-43c3-8228-83ed2d9c0472} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt32OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:28.370763 [ 6609 ] {7a52a430-c256-4db9-9081-12d587805c37} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetInt64([], []);) 2025.10.23 23:30:28.377179 [ 6609 ] {7a52a430-c256-4db9-9081-12d587805c37} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:28.465195 [ 6609 ] {e9c28b62-0098-4059-80d1-0f2fba6071bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetInt64OrDefault([], []);) 2025.10.23 23:30:28.515742 [ 6609 ] {e9c28b62-0098-4059-80d1-0f2fba6071bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt64OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:28.531073 [ 4227 ] {8c2efeb3-ea57-4eac-a35e-6680d6796bab} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:28.537555 [ 4227 ] {8c2efeb3-ea57-4eac-a35e-6680d6796bab} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:28.555503 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (8 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:28.605545 [ 6609 ] {37d478da-8bbf-4a46-99ca-74e2478cd6ff} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetInt8([], []);) 2025.10.23 23:30:28.615249 [ 6609 ] {37d478da-8bbf-4a46-99ca-74e2478cd6ff} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:28.687303 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:28.715049 [ 6609 ] {a6d237e9-6276-4b24-9280-f30c5a3bf192} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetInt8OrDefault([], []);) 2025.10.23 23:30:28.732779 [ 6609 ] {a6d237e9-6276-4b24-9280-f30c5a3bf192} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetInt8OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:28.847019 [ 3016 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:28.961254 [ 6609 ] {d3aa142f-806e-4aff-b26f-78e0be6e65bd} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetOrDefault([], []);) 2025.10.23 23:30:28.963893 [ 6609 ] {d3aa142f-806e-4aff-b26f-78e0be6e65bd} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGetOrDefault: In scope SELECT dictGetOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:29.085549 [ 3024 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:29.090924 [ 6609 ] {be69f532-6184-430c-be50-5069d0d88556} executeQuery: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetOrNull([], []);) 2025.10.23 23:30:29.093397 [ 6609 ] {be69f532-6184-430c-be50-5069d0d88556} TCPHandler: Code: 42. DB::Exception: Wrong argument count for function dictGet: In scope SELECT dictGetOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:29.170399 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:29.224659 [ 6609 ] {1f1d901a-d829-45c1-9dd3-f3dbf6d5b045} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetString([], []);) 2025.10.23 23:30:29.229936 [ 6609 ] {1f1d901a-d829-45c1-9dd3-f3dbf6d5b045} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetString doesn't match: the function requires more arguments: In scope SELECT dictGetString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:29.293063 [ 6609 ] {4ea44edc-276b-4eaf-8959-dd397f5959a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetStringOrDefault([], []);) 2025.10.23 23:30:29.296961 [ 6609 ] {4ea44edc-276b-4eaf-8959-dd397f5959a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetStringOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetStringOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:29.444437 [ 6609 ] {5575f9a4-409a-4e8f-86ef-38d6860b8aa3} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUInt16([], []);) 2025.10.23 23:30:29.449485 [ 6609 ] {5575f9a4-409a-4e8f-86ef-38d6860b8aa3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:29.549765 [ 6609 ] {abefaac0-b184-4146-9c84-116cd3e61b90} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUInt16OrDefault([], []);) 2025.10.23 23:30:29.552122 [ 6609 ] {abefaac0-b184-4146-9c84-116cd3e61b90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt16OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt16OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:29.761372 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:29.774378 [ 6609 ] {8c25b76b-b27b-4cfc-9c49-13b23193c56d} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUInt32([], []);) 2025.10.23 23:30:29.781926 [ 6609 ] {8c25b76b-b27b-4cfc-9c49-13b23193c56d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:29.849051 [ 3041 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:29.906514 [ 3495 ] {05ba571d-a435-4718-95c0-f97a4c047f63} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:29.913737 [ 3495 ] {05ba571d-a435-4718-95c0-f97a4c047f63} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:29.925852 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (8 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:29.926390 [ 6609 ] {7acbf4c0-f9c4-4a35-9ae5-fb11a3577504} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUInt32OrDefault([], []);) 2025.10.23 23:30:29.943026 [ 6609 ] {7acbf4c0-f9c4-4a35-9ae5-fb11a3577504} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt32OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt32OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:30.049423 [ 6609 ] {95102f4c-d607-44d5-8b88-b1e53c064dc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUInt64([], []);) 2025.10.23 23:30:30.058094 [ 6609 ] {95102f4c-d607-44d5-8b88-b1e53c064dc8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:30.087839 [ 3049 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:30.150765 [ 6609 ] {0ebdcadd-cbdd-4d77-a2cf-8a6c24766b83} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUInt64OrDefault([], []);) 2025.10.23 23:30:30.162015 [ 6609 ] {0ebdcadd-cbdd-4d77-a2cf-8a6c24766b83} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt64OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt64OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:30.208543 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:30.224846 [ 6609 ] {121fe8a0-8cd0-4db6-b555-582f61a0d0a9} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUInt8([], []);) 2025.10.23 23:30:30.236097 [ 6609 ] {121fe8a0-8cd0-4db6-b555-582f61a0d0a9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8 doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:30.318977 [ 6609 ] {f490d851-24e6-4b70-ae31-5fec4e6c1a00} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUInt8OrDefault([], []);) 2025.10.23 23:30:30.325394 [ 6609 ] {f490d851-24e6-4b70-ae31-5fec4e6c1a00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUInt8OrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUInt8OrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:30.406486 [ 6609 ] {a7688658-a29d-4995-976e-74f58d91d6b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUUID([], []);) 2025.10.23 23:30:30.416572 [ 6609 ] {a7688658-a29d-4995-976e-74f58d91d6b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUID doesn't match: the function requires more arguments: In scope SELECT dictGetUUID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:30.423959 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:30.514168 [ 6609 ] {a54c30d7-012d-4729-9343-73c503c61510} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictGetUUIDOrDefault([], []);) 2025.10.23 23:30:30.533783 [ 6609 ] {a54c30d7-012d-4729-9343-73c503c61510} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictGetUUIDOrDefault doesn't match: the function requires more arguments: In scope SELECT dictGetUUIDOrDefault([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:30.626362 [ 6609 ] {080cefd8-02ef-4222-ba0e-e80fa63b5539} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictHas, expected a string: In scope SELECT dictHas([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictHas([], []);) 2025.10.23 23:30:30.635559 [ 6609 ] {080cefd8-02ef-4222-ba0e-e80fa63b5539} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function dictHas, expected a string: In scope SELECT dictHas([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:30.730346 [ 6609 ] {28e74e61-54de-4791-be43-14c654928681} executeQuery: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dictIsIn([], []);) 2025.10.23 23:30:30.746439 [ 6609 ] {28e74e61-54de-4791-be43-14c654928681} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dictIsIn doesn't match: passed 2, should be 3: In scope SELECT dictIsIn([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:30.851640 [ 3053 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:30.856038 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:30.968241 [ 6609 ] {2f89840c-6d40-4851-ba60-89e9b8f04859} executeQuery: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT displayName([], []);) 2025.10.23 23:30:30.972338 [ 6609 ] {2f89840c-6d40-4851-ba60-89e9b8f04859} TCPHandler: Code: 42. DB::Exception: Number of arguments for function displayName doesn't match: passed 2, should be 0: In scope SELECT displayName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:31.086048 [ 6609 ] {50a41502-1b9a-426e-8252-57aa60595b9a} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL1Distance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceL1([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT distanceL1([], []);) 2025.10.23 23:30:31.090359 [ 3059 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:31.090459 [ 6609 ] {50a41502-1b9a-426e-8252-57aa60595b9a} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL1Distance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceL1([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:31.179398 [ 6609 ] {52e63c8d-cec3-45ba-a6ca-777f98f9819c} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL2Distance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceL2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT distanceL2([], []);) 2025.10.23 23:30:31.183987 [ 6609 ] {52e63c8d-cec3-45ba-a6ca-777f98f9819c} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL2Distance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceL2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:31.212827 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:31.249646 [ 6609 ] {bf9e6732-2484-480d-b1fc-7255b474d86a} executeQuery: Code: 43. DB::Exception: Arguments of function arrayL2SquaredDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceL2Squared([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT distanceL2Squared([], []);) 2025.10.23 23:30:31.257808 [ 6609 ] {bf9e6732-2484-480d-b1fc-7255b474d86a} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayL2SquaredDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceL2Squared([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:31.332499 [ 6609 ] {4dfbae24-16d6-459f-8111-c450a6fad1e6} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLinfDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceLinf([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT distanceLinf([], []);) 2025.10.23 23:30:31.337790 [ 6609 ] {4dfbae24-16d6-459f-8111-c450a6fad1e6} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLinfDistance has nested type Nothing. Supported types: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT distanceLinf([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:31.388618 [ 6609 ] {97fc79d0-e72d-4963-a36e-a90a115da78a} executeQuery: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT distanceLp([], []);) 2025.10.23 23:30:31.393432 [ 6609 ] {97fc79d0-e72d-4963-a36e-a90a115da78a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LpDistance doesn't match: passed 2, should be 3: In scope SELECT distanceLp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:31.513456 [ 6609 ] {837f1aa2-fcd3-453a-b493-1ae6d2a2d1cd} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function divide: In scope SELECT [] / []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT divide([], []);) 2025.10.23 23:30:31.520112 [ 6609 ] {837f1aa2-fcd3-453a-b493-1ae6d2a2d1cd} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function divide: In scope SELECT [] / []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:31.626684 [ 6609 ] {9e0b09b6-741b-4b73-9234-ed0312382f3a} executeQuery: Code: 43. DB::Exception: Arguments for divideDecimal function must be Decimal: In scope SELECT divideDecimal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT divideDecimal([], []);) 2025.10.23 23:30:31.634593 [ 6609 ] {9e0b09b6-741b-4b73-9234-ed0312382f3a} TCPHandler: Code: 43. DB::Exception: Arguments for divideDecimal function must be Decimal: In scope SELECT divideDecimal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:31.728453 [ 6609 ] {68199175-b671-4672-a570-875c7c8779af} executeQuery: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT domain([], []);) 2025.10.23 23:30:31.739444 [ 6609 ] {68199175-b671-4672-a570-875c7c8779af} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domain doesn't match: passed 2, should be 1: In scope SELECT domain([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:31.836199 [ 6609 ] {d93afb1e-1298-41f2-8bfc-cff926916c94} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT domainRFC([], []);) 2025.10.23 23:30:31.844808 [ 6609 ] {d93afb1e-1298-41f2-8bfc-cff926916c94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainRFC doesn't match: passed 2, should be 1: In scope SELECT domainRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:31.857403 [ 3067 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:31.909457 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:32.034585 [ 6609 ] {468c2e22-17e8-45dc-9211-9b4429fdbd10} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT domainWithoutWWW([], []);) 2025.10.23 23:30:32.052122 [ 6609 ] {468c2e22-17e8-45dc-9211-9b4429fdbd10} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWW doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWW([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:32.092789 [ 3071 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:32.210124 [ 6609 ] {ce87fe64-01a5-46ca-9c11-6244681cc459} executeQuery: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT domainWithoutWWWRFC([], []);) 2025.10.23 23:30:32.267226 [ 6609 ] {ce87fe64-01a5-46ca-9c11-6244681cc459} TCPHandler: Code: 42. DB::Exception: Number of arguments for function domainWithoutWWWRFC doesn't match: passed 2, should be 1: In scope SELECT domainWithoutWWWRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:32.274076 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:32.417381 [ 6609 ] {1a84fd87-100c-433d-8d23-86fdd1b3072c} executeQuery: Code: 43. DB::Exception: Function arrayDotProduct cannot process values of type Nothing: In scope SELECT dotProduct([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dotProduct([], []);) 2025.10.23 23:30:32.422944 [ 6609 ] {1a84fd87-100c-433d-8d23-86fdd1b3072c} TCPHandler: Code: 43. DB::Exception: Function arrayDotProduct cannot process values of type Nothing: In scope SELECT dotProduct([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:32.574654 [ 6609 ] {e2f8aac1-954a-4cfb-acab-4b6798d6c930} executeQuery: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dumpColumnStructure([], []);) 2025.10.23 23:30:32.577191 [ 6609 ] {e2f8aac1-954a-4cfb-acab-4b6798d6c930} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dumpColumnStructure doesn't match: passed 2, should be 1: In scope SELECT dumpColumnStructure([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:32.671333 [ 6609 ] {903f098f-638f-419a-974b-3711bcbd57da} executeQuery: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Array(Nothing): In scope SELECT dynamicElement([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dynamicElement([], []);) 2025.10.23 23:30:32.680253 [ 6609 ] {903f098f-638f-419a-974b-3711bcbd57da} TCPHandler: Code: 43. DB::Exception: First argument for function dynamicElement must be Variant or Array of Variant. Actual Array(Nothing): In scope SELECT dynamicElement([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:32.792371 [ 6609 ] {68117784-6596-4af8-a5ce-ecf0b70406ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT dynamicType([], []);) 2025.10.23 23:30:32.814110 [ 6609 ] {68117784-6596-4af8-a5ce-ecf0b70406ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function dynamicType doesn't match: passed 2, should be 1: In scope SELECT dynamicType([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:32.860211 [ 3083 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:32.958245 [ 6609 ] {4e2911da-5c65-4862-8575-bf41a86956ec} executeQuery: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT e([], []);) 2025.10.23 23:30:32.961045 [ 6609 ] {4e2911da-5c65-4862-8575-bf41a86956ec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function e doesn't match: passed 2, should be 0: In scope SELECT e([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:32.979866 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:33.086418 [ 6609 ] {c9a603b9-a2d6-469b-8e85-da4199526936} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function editDistance: In scope SELECT editDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT editDistance([], []);) 2025.10.23 23:30:33.094838 [ 3090 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:33.095449 [ 6609 ] {c9a603b9-a2d6-469b-8e85-da4199526936} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function editDistance: In scope SELECT editDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:33.214099 [ 6609 ] {230f8651-9ece-43f9-be2d-0fda7bc6ea1f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function editDistanceUTF8: In scope SELECT editDistanceUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT editDistanceUTF8([], []);) 2025.10.23 23:30:33.235670 [ 6609 ] {230f8651-9ece-43f9-be2d-0fda7bc6ea1f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function editDistanceUTF8: In scope SELECT editDistanceUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:33.373062 [ 6609 ] {656d7a1c-fbb3-4a21-bbf2-6c104cfb1d20} executeQuery: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT empty([], []);) 2025.10.23 23:30:33.380042 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:33.441122 [ 6609 ] {656d7a1c-fbb3-4a21-bbf2-6c104cfb1d20} TCPHandler: Code: 42. DB::Exception: Number of arguments for function empty doesn't match: passed 2, should be 1: In scope SELECT empty([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:33.514226 [ 6609 ] {128a6904-c8b4-4abc-b0e9-3a86961ed18f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayDate([], []);) 2025.10.23 23:30:33.518759 [ 6609 ] {128a6904-c8b4-4abc-b0e9-3a86961ed18f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDate doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:33.565251 [ 6609 ] {35f815f8-2db2-4e3d-b476-e28fbdaa785d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayDateTime([], []);) 2025.10.23 23:30:33.570501 [ 6609 ] {35f815f8-2db2-4e3d-b476-e28fbdaa785d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayDateTime doesn't match: passed 2, should be 0: In scope SELECT emptyArrayDateTime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:33.633660 [ 6609 ] {9ea210d5-9c6e-42b0-9319-24705beca5d7} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayFloat32([], []);) 2025.10.23 23:30:33.637565 [ 6609 ] {9ea210d5-9c6e-42b0-9319-24705beca5d7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:33.724384 [ 6609 ] {b0b462aa-c9ee-4ed1-9e11-0453c25aed0e} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayFloat64([], []);) 2025.10.23 23:30:33.731278 [ 6609 ] {b0b462aa-c9ee-4ed1-9e11-0453c25aed0e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayFloat64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayFloat64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:33.862480 [ 3102 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:33.890058 [ 6609 ] {c980d0bc-d49b-4f75-b770-597baf97ee54} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayInt16([], []);) 2025.10.23 23:30:33.896186 [ 6609 ] {c980d0bc-d49b-4f75-b770-597baf97ee54} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:33.988477 [ 6609 ] {35dcafa6-a246-4523-ba65-eb7a7a608c6f} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayInt32([], []);) 2025.10.23 23:30:33.994750 [ 6609 ] {35dcafa6-a246-4523-ba65-eb7a7a608c6f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.091582 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:34.099843 [ 3108 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:34.114587 [ 6609 ] {2e6002a2-bef3-4a4f-96dc-c4984ddab5f5} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayInt64([], []);) 2025.10.23 23:30:34.128911 [ 6609 ] {2e6002a2-bef3-4a4f-96dc-c4984ddab5f5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.216945 [ 6609 ] {b9b2e630-69d5-4486-84ac-12adc3100b7c} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayInt8([], []);) 2025.10.23 23:30:34.225969 [ 6609 ] {b9b2e630-69d5-4486-84ac-12adc3100b7c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.305342 [ 6609 ] {0a9bc177-0ee4-4315-b13d-5243286ae8cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayString([], []);) 2025.10.23 23:30:34.319213 [ 6609 ] {0a9bc177-0ee4-4315-b13d-5243286ae8cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayString doesn't match: passed 2, should be 0: In scope SELECT emptyArrayString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.354611 [ 4227 ] {9a619989-f7de-40e7-966c-f795f5cc423c} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:34.395504 [ 4227 ] {9a619989-f7de-40e7-966c-f795f5cc423c} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:34.401211 [ 6609 ] {83dbcffd-0a65-4f87-8782-6a6d4d240fd2} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayToSingle([], []);) 2025.10.23 23:30:34.403805 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (9 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:34.406519 [ 6609 ] {83dbcffd-0a65-4f87-8782-6a6d4d240fd2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayToSingle doesn't match: passed 2, should be 1: In scope SELECT emptyArrayToSingle([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.442826 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:34.534990 [ 6609 ] {ec94b3a7-0651-4868-9572-bc173db2c098} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayUInt16([], []);) 2025.10.23 23:30:34.550567 [ 6609 ] {ec94b3a7-0651-4868-9572-bc173db2c098} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt16 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.605015 [ 6609 ] {3f2e48ec-c6a5-49b2-82b4-ee86edbbac9b} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayUInt32([], []);) 2025.10.23 23:30:34.610680 [ 6609 ] {3f2e48ec-c6a5-49b2-82b4-ee86edbbac9b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt32 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.657920 [ 6609 ] {65b78aed-a12f-48ce-8b3a-40da396752cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayUInt64([], []);) 2025.10.23 23:30:34.662095 [ 6609 ] {65b78aed-a12f-48ce-8b3a-40da396752cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt64 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.731225 [ 6609 ] {278bcf7f-0896-4c30-bd00-a866ee9ba22d} executeQuery: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT emptyArrayUInt8([], []);) 2025.10.23 23:30:34.744490 [ 6609 ] {278bcf7f-0896-4c30-bd00-a866ee9ba22d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function emptyArrayUInt8 doesn't match: passed 2, should be 0: In scope SELECT emptyArrayUInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.844832 [ 6609 ] {e59bac35-70db-42cc-9cdd-231bfbb71f4b} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT enabledProfiles([], []);) 2025.10.23 23:30:34.863333 [ 6609 ] {e59bac35-70db-42cc-9cdd-231bfbb71f4b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledProfiles doesn't match: passed 2, should be 0: In scope SELECT enabledProfiles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:34.864812 [ 3118 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:34.977613 [ 6609 ] {b49b017f-47c9-4ea5-8dd6-03539690c0b8} executeQuery: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT enabledRoles([], []);) 2025.10.23 23:30:34.983380 [ 6609 ] {b49b017f-47c9-4ea5-8dd6-03539690c0b8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function enabledRoles doesn't match: passed 2, should be 0: In scope SELECT enabledRoles([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:35.057089 [ 6609 ] {707ad405-2a84-4316-88be-661af1be3b87} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT encodeURLComponent([], []);) 2025.10.23 23:30:35.061165 [ 6609 ] {707ad405-2a84-4316-88be-661af1be3b87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:35.108995 [ 3123 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:35.145459 [ 6609 ] {dd7a86e8-5909-4f35-accc-7d668b6d1898} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT encodeURLFormComponent([], []);) 2025.10.23 23:30:35.159146 [ 6609 ] {dd7a86e8-5909-4f35-accc-7d668b6d1898} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeURLFormComponent doesn't match: passed 2, should be 1: In scope SELECT encodeURLFormComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:35.196458 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:35.231582 [ 6609 ] {8e8f3496-954d-46c0-94dd-c554f0857d26} executeQuery: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT encodeXMLComponent([], []);) 2025.10.23 23:30:35.236585 [ 6609 ] {8e8f3496-954d-46c0-94dd-c554f0857d26} TCPHandler: Code: 42. DB::Exception: Number of arguments for function encodeXMLComponent doesn't match: passed 2, should be 1: In scope SELECT encodeXMLComponent([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:35.340700 [ 6609 ] {e725a678-3e5e-4daa-bb98-39dc94e8a7c5} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT encrypt([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT encrypt([], '[HIDDEN]')) 2025.10.23 23:30:35.346591 [ 6609 ] {e725a678-3e5e-4daa-bb98-39dc94e8a7c5} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'encrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT encrypt([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:35.488166 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:35.518437 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:35.604442 [ 3495 ] {e0f58196-f35c-40b6-aa9e-3c173a963cee} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:35.608408 [ 3495 ] {e0f58196-f35c-40b6-aa9e-3c173a963cee} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:35.623522 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (9 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:35.867508 [ 3132 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:36.031367 [ 6609 ] {c2cf5b52-3155-4fe7-bba1-8933c039cd2c} executeQuery: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT erf([], []);) 2025.10.23 23:30:36.037849 [ 6609 ] {c2cf5b52-3155-4fe7-bba1-8933c039cd2c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erf doesn't match: passed 2, should be 1: In scope SELECT erf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:36.111476 [ 3136 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:36.181044 [ 6609 ] {3e60d2f5-6c31-40b1-95c1-4f852a1c566e} executeQuery: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT erfc([], []);) 2025.10.23 23:30:36.194359 [ 6609 ] {3e60d2f5-6c31-40b1-95c1-4f852a1c566e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function erfc doesn't match: passed 2, should be 1: In scope SELECT erfc([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:36.320146 [ 6609 ] {5f60e8db-1de5-4d19-a9e9-fa20e2bf980f} executeQuery: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT errorCodeToName([], []);) 2025.10.23 23:30:36.324645 [ 6609 ] {5f60e8db-1de5-4d19-a9e9-fa20e2bf980f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function errorCodeToName doesn't match: passed 2, should be 1: In scope SELECT errorCodeToName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:36.346687 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:36.455229 [ 6609 ] {3cd7d695-dbfb-4c24-8ac4-ce1137f214ff} executeQuery: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT evalMLMethod([], []);) 2025.10.23 23:30:36.477252 [ 6609 ] {3cd7d695-dbfb-4c24-8ac4-ce1137f214ff} TCPHandler: Code: 43. DB::Exception: Argument for function evalMLMethod must have type AggregateFunction - state of aggregate function.: In scope SELECT evalMLMethod([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:36.530999 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:36.558783 [ 6609 ] {e1ab3a8a-d7a1-4e43-83a4-77032188eb3a} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT exp([], []);) 2025.10.23 23:30:36.564693 [ 6609 ] {e1ab3a8a-d7a1-4e43-83a4-77032188eb3a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp doesn't match: passed 2, should be 1: In scope SELECT exp([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:36.644503 [ 6609 ] {39601dd2-8738-4677-b7a1-e963990fbc2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT exp10([], []);) 2025.10.23 23:30:36.650432 [ 6609 ] {39601dd2-8738-4677-b7a1-e963990fbc2a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp10 doesn't match: passed 2, should be 1: In scope SELECT exp10([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:36.712042 [ 6609 ] {d333d20e-72f7-4a2e-a429-e3709ccd7df4} executeQuery: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT exp2([], []);) 2025.10.23 23:30:36.717408 [ 6609 ] {d333d20e-72f7-4a2e-a429-e3709ccd7df4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function exp2 doesn't match: passed 2, should be 1: In scope SELECT exp2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:36.767293 [ 6609 ] {e23492eb-4746-4a84-9546-329bb4634c7e} executeQuery: Code: 43. DB::Exception: Both arguments for aggregate function exponentialMovingAverage must have numeric type, got Array(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT exponentialMovingAverage([], []);) 2025.10.23 23:30:36.771534 [ 6609 ] {e23492eb-4746-4a84-9546-329bb4634c7e} TCPHandler: Code: 43. DB::Exception: Both arguments for aggregate function exponentialMovingAverage must have numeric type, got Array(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:36.813044 [ 6609 ] {fa506828-a8a1-457e-bb2b-639b225f4a50} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT exponentialTimeDecayedAvg([], []);) 2025.10.23 23:30:36.817241 [ 6609 ] {fa506828-a8a1-457e-bb2b-639b225f4a50} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedAvg takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:36.860605 [ 6609 ] {d0983fec-fc62-44f1-ad08-27bbe0030b32} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT exponentialTimeDecayedCount([], []);) 2025.10.23 23:30:36.864173 [ 6609 ] {d0983fec-fc62-44f1-ad08-27bbe0030b32} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedCount takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:36.871858 [ 3149 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:36.936302 [ 6609 ] {fe89eac0-6f87-425b-9623-d135e7629838} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT exponentialTimeDecayedMax([], []);) 2025.10.23 23:30:36.941440 [ 6609 ] {fe89eac0-6f87-425b-9623-d135e7629838} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedMax takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:37.116764 [ 6609 ] {1c8be565-d2b5-415f-aab6-84f491ae5356} executeQuery: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT exponentialTimeDecayedSum([], []);) 2025.10.23 23:30:37.119966 [ 3154 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:37.121416 [ 6609 ] {1c8be565-d2b5-415f-aab6-84f491ae5356} TCPHandler: Code: 42. DB::Exception: Function exponentialTimeDecayedSum takes exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:37.229268 [ 6609 ] {38749c65-5b2a-4d76-bdfc-fa14580b7f62} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function extract: In scope SELECT extract([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extract([], []);) 2025.10.23 23:30:37.246664 [ 6609 ] {38749c65-5b2a-4d76-bdfc-fa14580b7f62} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function extract: In scope SELECT extract([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:37.365102 [ 6609 ] {3597c73b-0bcc-4bf3-99a6-633d0067f84e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAll'. Expected: String, got: Array(Nothing): In scope SELECT extractAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractAll([], []);) 2025.10.23 23:30:37.373177 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:37.374252 [ 6609 ] {3597c73b-0bcc-4bf3-99a6-633d0067f84e} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAll'. Expected: String, got: Array(Nothing): In scope SELECT extractAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:37.484659 [ 6609 ] {ec7f1d92-de18-4dfc-b3d9-500d496be256} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: Array(Nothing): In scope SELECT extractAllGroups([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractAllGroups([], []);) 2025.10.23 23:30:37.489501 [ 6609 ] {ec7f1d92-de18-4dfc-b3d9-500d496be256} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: Array(Nothing): In scope SELECT extractAllGroups([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:37.538409 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:37.548053 [ 6609 ] {b66ceff6-a358-4db3-8569-39f5c6c741d1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: Array(Nothing): In scope SELECT extractAllGroupsHorizontal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractAllGroupsHorizontal([], []);) 2025.10.23 23:30:37.562439 [ 6609 ] {b66ceff6-a358-4db3-8569-39f5c6c741d1} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsHorizontal'. Expected: const String or const FixedString, got: Array(Nothing): In scope SELECT extractAllGroupsHorizontal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:37.647116 [ 6609 ] {b75183bc-8e94-477f-9f67-6bd4b0b63c67} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: Array(Nothing): In scope SELECT extractAllGroupsVertical([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractAllGroupsVertical([], []);) 2025.10.23 23:30:37.651560 [ 6609 ] {b75183bc-8e94-477f-9f67-6bd4b0b63c67} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractAllGroupsVertical'. Expected: const String or const FixedString, got: Array(Nothing): In scope SELECT extractAllGroupsVertical([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:37.703009 [ 6609 ] {feb7e314-47ea-4c6d-b92a-1919af68476d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractGroups'. Expected: const String or const FixedString, got: Array(Nothing): In scope SELECT extractGroups([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractGroups([], []);) 2025.10.23 23:30:37.709044 [ 6609 ] {feb7e314-47ea-4c6d-b92a-1919af68476d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'extractGroups'. Expected: const String or const FixedString, got: Array(Nothing): In scope SELECT extractGroups([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:37.766443 [ 6609 ] {5cc0042c-6499-4898-a216-d3dd90a220f9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractKeyValuePairs([], []);) 2025.10.23 23:30:37.772543 [ 6609 ] {5cc0042c-6499-4898-a216-d3dd90a220f9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairs([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:37.803084 [ 9658 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:30:43: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:37.821553 [ 6609 ] {411b02f5-d42b-4175-8ddd-b3ddbf04322e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractKeyValuePairsWithEscaping([], []);) 2025.10.23 23:30:37.873918 [ 3163 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:37.915456 [ 6609 ] {411b02f5-d42b-4175-8ddd-b3ddbf04322e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT extractKeyValuePairsWithEscaping([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:37.973749 [ 6609 ] {c59461d4-d4a4-47a0-b9b5-d7e114ed1352} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractTextFromHTML([], []);) 2025.10.23 23:30:37.985104 [ 6609 ] {c59461d4-d4a4-47a0-b9b5-d7e114ed1352} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractTextFromHTML doesn't match: passed 2, should be 1: In scope SELECT extractTextFromHTML([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:38.058046 [ 6609 ] {7e9e2e8b-6684-4aac-a1c8-4b78d8f9498d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function extractURLParameter: In scope SELECT extractURLParameter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractURLParameter([], []);) 2025.10.23 23:30:38.064113 [ 6609 ] {7e9e2e8b-6684-4aac-a1c8-4b78d8f9498d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function extractURLParameter: In scope SELECT extractURLParameter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:38.121900 [ 3171 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:38.199544 [ 6609 ] {e30b968a-6beb-422f-ae9e-92c083603a05} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractURLParameterNames([], []);) 2025.10.23 23:30:38.214860 [ 6609 ] {e30b968a-6beb-422f-ae9e-92c083603a05} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameterNames doesn't match: passed 2, should be 1: In scope SELECT extractURLParameterNames([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:38.317203 [ 6609 ] {758d1cfd-0e15-40fd-a55c-8ca9f4b06a2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT extractURLParameters([], []);) 2025.10.23 23:30:38.325584 [ 6609 ] {758d1cfd-0e15-40fd-a55c-8ca9f4b06a2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function extractURLParameters doesn't match: passed 2, should be 1: In scope SELECT extractURLParameters([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:38.471049 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:38.505658 [ 6609 ] {4abd7dec-d826-4a5d-ba1e-faf9df8e3815} executeQuery: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT factorial([], []);) 2025.10.23 23:30:38.513857 [ 6609 ] {4abd7dec-d826-4a5d-ba1e-faf9df8e3815} TCPHandler: Code: 42. DB::Exception: Number of arguments for function factorial doesn't match: passed 2, should be 1: In scope SELECT factorial([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:38.617592 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:38.876023 [ 3183 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:38.882681 [ 6609 ] {b1864070-48fa-4c6c-898f-eabe2669b3b9} executeQuery: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file([], []). (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT file([], []);) 2025.10.23 23:30:38.886072 [ 6609 ] {b1864070-48fa-4c6c-898f-eabe2669b3b9} TCPHandler: Code: 48. DB::Exception: file is only implemented for type String: In scope SELECT file([], []). (NOT_IMPLEMENTED) 2025.10.23 23:30:38.932977 [ 6609 ] {83f83d5f-2c87-4027-a84c-6e4d1ca24e69} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemAvailable should be 0 or 1: In scope SELECT filesystemAvailable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT filesystemAvailable([], []);) 2025.10.23 23:30:38.936819 [ 6609 ] {83f83d5f-2c87-4027-a84c-6e4d1ca24e69} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemAvailable should be 0 or 1: In scope SELECT filesystemAvailable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:38.976392 [ 6609 ] {e6d4e4d1-b17f-4f08-aecc-a667a9d6765c} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemCapacity should be 0 or 1: In scope SELECT filesystemCapacity([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT filesystemCapacity([], []);) 2025.10.23 23:30:38.980576 [ 6609 ] {e6d4e4d1-b17f-4f08-aecc-a667a9d6765c} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemCapacity should be 0 or 1: In scope SELECT filesystemCapacity([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:39.026209 [ 6609 ] {f29ffc31-8397-4e33-9a88-64057402f3f1} executeQuery: Code: 42. DB::Exception: Arguments size of function filesystemUnreserved should be 0 or 1: In scope SELECT filesystemUnreserved([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT filesystemUnreserved([], []);) 2025.10.23 23:30:39.030391 [ 6609 ] {f29ffc31-8397-4e33-9a88-64057402f3f1} TCPHandler: Code: 42. DB::Exception: Arguments size of function filesystemUnreserved should be 0 or 1: In scope SELECT filesystemUnreserved([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:39.075187 [ 6609 ] {1610b041-2c19-4a52-b346-c841325b7d61} executeQuery: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT finalizeAggregation([], []);) 2025.10.23 23:30:39.089825 [ 6609 ] {1610b041-2c19-4a52-b346-c841325b7d61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function finalizeAggregation doesn't match: passed 2, should be 1: In scope SELECT finalizeAggregation([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:39.123772 [ 3189 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:39.168485 [ 6609 ] {71c1a41f-c894-4726-bee5-7370a056dbec} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT firstLine([], []);) 2025.10.23 23:30:39.181616 [ 6609 ] {71c1a41f-c894-4726-bee5-7370a056dbec} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstLine doesn't match: passed 2, should be 1: In scope SELECT firstLine([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:39.407083 [ 6609 ] {3c5de204-c49a-48cc-a276-2bb839ca5994} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT firstSignificantSubdomain([], []);) 2025.10.23 23:30:39.413501 [ 6609 ] {3c5de204-c49a-48cc-a276-2bb839ca5994} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomain doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomain([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:39.482250 [ 6609 ] {d954fd3c-1d14-46dd-86bb-e3a5d6196ab5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function firstSignificantSubdomainCustom. Must be String.: In scope SELECT firstSignificantSubdomainCustom([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT firstSignificantSubdomainCustom([], []);) 2025.10.23 23:30:39.486319 [ 6609 ] {d954fd3c-1d14-46dd-86bb-e3a5d6196ab5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function firstSignificantSubdomainCustom. Must be String.: In scope SELECT firstSignificantSubdomainCustom([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:39.541783 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:39.755155 [ 6609 ] {2fa21333-1fd4-4dd7-9a06-5deacac983c5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function firstSignificantSubdomainCustomRFC. Must be String.: In scope SELECT firstSignificantSubdomainCustomRFC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT firstSignificantSubdomainCustomRFC([], []);) 2025.10.23 23:30:39.759465 [ 6609 ] {2fa21333-1fd4-4dd7-9a06-5deacac983c5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function firstSignificantSubdomainCustomRFC. Must be String.: In scope SELECT firstSignificantSubdomainCustomRFC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:39.788262 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:39.833175 [ 6609 ] {5fb723f6-792c-4baf-b101-25f69c921a24} executeQuery: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT firstSignificantSubdomainRFC([], []);) 2025.10.23 23:30:39.840398 [ 6609 ] {5fb723f6-792c-4baf-b101-25f69c921a24} TCPHandler: Code: 42. DB::Exception: Number of arguments for function firstSignificantSubdomainRFC doesn't match: passed 2, should be 1: In scope SELECT firstSignificantSubdomainRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:39.877995 [ 3198 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:39.997228 [ 6609 ] {cb032697-2567-485d-922d-428aa3f17ff4} executeQuery: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT first_value([], []);) 2025.10.23 23:30:40.004985 [ 6609 ] {cb032697-2567-485d-922d-428aa3f17ff4} TCPHandler: Code: 42. DB::Exception: Aggregate function any requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:40.067834 [ 6609 ] {25ca87f5-c553-4592-a999-59937ee94bb9} executeQuery: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT first_value_respect_nulls([], []);) 2025.10.23 23:30:40.073634 [ 6609 ] {25ca87f5-c553-4592-a999-59937ee94bb9} TCPHandler: Code: 42. DB::Exception: Aggregate function any_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:40.125728 [ 3203 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:40.137086 [ 6609 ] {ab21ab80-f512-4035-9420-9158cd4d5d1e} executeQuery: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT flameGraph([], []);) 2025.10.23 23:30:40.143982 [ 6609 ] {ab21ab80-f512-4035-9420-9158cd4d5d1e} TCPHandler: Code: 43. DB::Exception: First argument (trace) for function flameGraph must be Array(UInt64), but it has type Array(Nothing). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:40.194424 [ 4227 ] {6d0a3475-b93f-42d3-b2a4-c4838692b28c} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:40.199275 [ 4227 ] {6d0a3475-b93f-42d3-b2a4-c4838692b28c} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:40.223439 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (10 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:40.235709 [ 6609 ] {7616205f-ed1d-42ab-8b79-12b73f49a54e} executeQuery: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT flatten([], []);) 2025.10.23 23:30:40.248743 [ 6609 ] {7616205f-ed1d-42ab-8b79-12b73f49a54e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function arrayFlatten doesn't match: passed 2, should be 1: In scope SELECT flatten([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:40.398479 [ 6609 ] {3a71826b-6778-4713-b6ad-b90bee890cb9} executeQuery: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT flattenTuple([], []);) 2025.10.23 23:30:40.420370 [ 6609 ] {3a71826b-6778-4713-b6ad-b90bee890cb9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function flattenTuple doesn't match: passed 2, should be 1: In scope SELECT flattenTuple([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:40.526882 [ 6609 ] {cb3e56c2-c0ca-472d-98a8-f730029b53f1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'floor'. Expected: A number to round, got: Array(Nothing): In scope SELECT floor([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT floor([], []);) 2025.10.23 23:30:40.530973 [ 6609 ] {cb3e56c2-c0ca-472d-98a8-f730029b53f1} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'floor'. Expected: A number to round, got: Array(Nothing): In scope SELECT floor([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:40.576225 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:40.623103 [ 6609 ] {56210ee1-447e-4436-b95e-5be9a867628d} executeQuery: Code: 170. DB::Exception: Bad get: has Array, requested String: In scope SELECT format([], []). (BAD_GET) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT format([], []);) 2025.10.23 23:30:40.626353 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:40.630929 [ 6609 ] {56210ee1-447e-4436-b95e-5be9a867628d} TCPHandler: Code: 170. DB::Exception: Bad get: has Array, requested String: In scope SELECT format([], []). (BAD_GET) 2025.10.23 23:30:40.709711 [ 6609 ] {b35d7c67-3072-4506-ad7f-4df1d7e67e9d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatDateTime([], []);) 2025.10.23 23:30:40.717970 [ 6609 ] {b35d7c67-3072-4506-ad7f-4df1d7e67e9d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTime. Should be a date or a date with time: In scope SELECT formatDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:40.819998 [ 6609 ] {87e08666-66dc-4f45-be31-4c953dea6167} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTimeInJodaSyntax. Should be a date or a date with time: In scope SELECT formatDateTimeInJodaSyntax([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatDateTimeInJodaSyntax([], []);) 2025.10.23 23:30:40.832197 [ 6609 ] {87e08666-66dc-4f45-be31-4c953dea6167} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function formatDateTimeInJodaSyntax. Should be a date or a date with time: In scope SELECT formatDateTimeInJodaSyntax([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:40.876778 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:40.880309 [ 3213 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:40.883421 [ 6609 ] {b6f04553-2119-47b3-a585-d9f081322b79} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatQuery([], []);) 2025.10.23 23:30:40.888359 [ 6609 ] {b6f04553-2119-47b3-a585-d9f081322b79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuery doesn't match: passed 2, should be 1: In scope SELECT formatQuery([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:40.976107 [ 6609 ] {a4219308-3ff9-4272-8eaa-20ddcf0d23aa} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatQueryOrNull([], []);) 2025.10.23 23:30:40.982397 [ 6609 ] {a4219308-3ff9-4272-8eaa-20ddcf0d23aa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQueryOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQueryOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:41.048339 [ 6609 ] {6a48a08a-4cec-4122-ba19-5cd04615c9cc} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatQuerySingleLine([], []);) 2025.10.23 23:30:41.052362 [ 6609 ] {6a48a08a-4cec-4122-ba19-5cd04615c9cc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLine doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLine([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:41.122790 [ 6609 ] {e2ab358e-9e9a-46db-a9b1-60176188770a} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatQuerySingleLineOrNull([], []);) 2025.10.23 23:30:41.127927 [ 3219 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:41.134295 [ 6609 ] {e2ab358e-9e9a-46db-a9b1-60176188770a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatQuerySingleLineOrNull doesn't match: passed 2, should be 1: In scope SELECT formatQuerySingleLineOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:41.247208 [ 3495 ] {a3a2a20a-efb1-4b25-a119-975c1e197750} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:41.259970 [ 3495 ] {a3a2a20a-efb1-4b25-a119-975c1e197750} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:41.263630 [ 6609 ] {80a8809e-a36c-49b4-9282-88657493e1bf} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatReadableDecimalSize([], []);) 2025.10.23 23:30:41.282400 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (10 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:41.286177 [ 6609 ] {80a8809e-a36c-49b4-9282-88657493e1bf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableDecimalSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableDecimalSize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:41.397702 [ 6609 ] {bb758548-d410-4484-9fcd-d9574db7fb57} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatReadableQuantity([], []);) 2025.10.23 23:30:41.405439 [ 6609 ] {bb758548-d410-4484-9fcd-d9574db7fb57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableQuantity doesn't match: passed 2, should be 1: In scope SELECT formatReadableQuantity([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:41.510005 [ 6609 ] {b0b27521-ae37-43d9-b064-9d1dc4d1217a} executeQuery: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatReadableSize([], []);) 2025.10.23 23:30:41.528087 [ 6609 ] {b0b27521-ae37-43d9-b064-9d1dc4d1217a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function formatReadableSize doesn't match: passed 2, should be 1: In scope SELECT formatReadableSize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:41.634213 [ 6609 ] {a0e90b29-1a0c-445d-b190-e16602813aab} executeQuery: Code: 43. DB::Exception: Cannot format Array(Nothing) as time delta: In scope SELECT formatReadableTimeDelta([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatReadableTimeDelta([], []);) 2025.10.23 23:30:41.649199 [ 6609 ] {a0e90b29-1a0c-445d-b190-e16602813aab} TCPHandler: Code: 43. DB::Exception: Cannot format Array(Nothing) as time delta: In scope SELECT formatReadableTimeDelta([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:41.657159 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:41.784705 [ 6609 ] {a0b5f2eb-036a-4460-b3ec-6f34ff0164d4} executeQuery: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatRow([], []);) 2025.10.23 23:30:41.795831 [ 6609 ] {a0b5f2eb-036a-4460-b3ec-6f34ff0164d4} TCPHandler: Code: 43. DB::Exception: First argument to formatRow must be a format name: In scope SELECT formatRow([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:41.862803 [ 6609 ] {e3e50bf6-ef9c-47f8-b606-151feede9e71} executeQuery: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT formatRowNoNewline([], []);) 2025.10.23 23:30:41.875245 [ 6609 ] {e3e50bf6-ef9c-47f8-b606-151feede9e71} TCPHandler: Code: 43. DB::Exception: First argument to formatRowNoNewline must be a format name: In scope SELECT formatRowNoNewline([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:41.882449 [ 3224 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:41.884806 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:41.954352 [ 6609 ] {f4670f2b-4363-4c31-86b3-021cf18d76ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fragment([], []);) 2025.10.23 23:30:41.960900 [ 6609 ] {f4670f2b-4363-4c31-86b3-021cf18d76ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fragment doesn't match: passed 2, should be 1: In scope SELECT fragment([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:42.080010 [ 6609 ] {8f36f2a2-e0d0-4271-aa6a-81dedaea05b7} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromDaysSinceYearZero([], []);) 2025.10.23 23:30:42.088578 [ 6609 ] {8f36f2a2-e0d0-4271-aa6a-81dedaea05b7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:42.130052 [ 3225 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:42.227069 [ 6609 ] {a93bbae8-85a9-4b81-8f04-178ebf169eea} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromDaysSinceYearZero32([], []);) 2025.10.23 23:30:42.231798 [ 6609 ] {a93bbae8-85a9-4b81-8f04-178ebf169eea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromDaysSinceYearZero32 doesn't match: passed 2, should be 1: In scope SELECT fromDaysSinceYearZero32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:42.331525 [ 6609 ] {ce18a1d3-d594-493d-a6c6-67b239c0452f} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromModifiedJulianDay([], []);) 2025.10.23 23:30:42.338549 [ 6609 ] {ce18a1d3-d594-493d-a6c6-67b239c0452f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDay([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:42.478191 [ 6609 ] {8b2666d1-c65f-41fb-b403-d6dc24a957e4} executeQuery: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromModifiedJulianDayOrNull([], []);) 2025.10.23 23:30:42.488136 [ 6609 ] {8b2666d1-c65f-41fb-b403-d6dc24a957e4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function fromModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT fromModifiedJulianDayOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:42.619572 [ 6609 ] {74993994-785a-420d-a376-0762da84f1bd} executeQuery: Code: 43. DB::Exception: Function fromUTCTimestamp's 1st argument type must be datetime.: In scope SELECT fromUTCTimestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromUTCTimestamp([], []);) 2025.10.23 23:30:42.626382 [ 6609 ] {74993994-785a-420d-a376-0762da84f1bd} TCPHandler: Code: 43. DB::Exception: Function fromUTCTimestamp's 1st argument type must be datetime.: In scope SELECT fromUTCTimestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:42.724102 [ 6609 ] {d34bad9e-8fb1-40d7-9d11-904f259874d4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromUnixTimestamp([], []);) 2025.10.23 23:30:42.730640 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:42.732298 [ 6609 ] {d34bad9e-8fb1-40d7-9d11-904f259874d4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestamp when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:42.849538 [ 6609 ] {ca2f33c8-aecb-48bc-bcbc-54d40b674e16} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Micro must be integer: In scope SELECT fromUnixTimestamp64Micro([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromUnixTimestamp64Micro([], []);) 2025.10.23 23:30:42.863399 [ 6609 ] {ca2f33c8-aecb-48bc-bcbc-54d40b674e16} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Micro must be integer: In scope SELECT fromUnixTimestamp64Micro([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:42.884744 [ 3240 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:42.918847 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:42.919931 [ 6609 ] {03e446c1-5437-46bf-ae26-5175fb57ed34} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Milli must be integer: In scope SELECT fromUnixTimestamp64Milli([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromUnixTimestamp64Milli([], []);) 2025.10.23 23:30:42.927969 [ 6609 ] {03e446c1-5437-46bf-ae26-5175fb57ed34} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Milli must be integer: In scope SELECT fromUnixTimestamp64Milli([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:43.022088 [ 6609 ] {4c2abd74-3fb3-43a4-9585-6eaadc436c1a} executeQuery: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Nano must be integer: In scope SELECT fromUnixTimestamp64Nano([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromUnixTimestamp64Nano([], []);) 2025.10.23 23:30:43.026622 [ 6609 ] {4c2abd74-3fb3-43a4-9585-6eaadc436c1a} TCPHandler: Code: 43. DB::Exception: The first argument for function fromUnixTimestamp64Nano must be integer: In scope SELECT fromUnixTimestamp64Nano([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:43.097885 [ 6609 ] {17c124ce-450b-4d8b-8315-c2158d4b86f6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestampInJodaSyntax([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fromUnixTimestampInJodaSyntax([], []);) 2025.10.23 23:30:43.103232 [ 6609 ] {17c124ce-450b-4d8b-8315-c2158d4b86f6} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function fromUnixTimestampInJodaSyntax when arguments size is 2 or 3. Should be a integer or a date with time: In scope SELECT fromUnixTimestampInJodaSyntax([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:43.132335 [ 3249 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:43.254678 [ 6609 ] {5da0c55b-2318-49c3-a7a3-0c1b9b75a6c7} executeQuery: Code: 43. DB::Exception: Function fromUTCTimestamp's 1st argument type must be datetime.: In scope SELECT from_utc_timestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT from_utc_timestamp([], []);) 2025.10.23 23:30:43.259441 [ 6609 ] {5da0c55b-2318-49c3-a7a3-0c1b9b75a6c7} TCPHandler: Code: 43. DB::Exception: Function fromUTCTimestamp's 1st argument type must be datetime.: In scope SELECT from_utc_timestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:43.311419 [ 6609 ] {6bdf4234-bc11-40d5-ac45-e2152c2701b0} executeQuery: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fullHostName([], []);) 2025.10.23 23:30:43.317298 [ 6609 ] {6bdf4234-bc11-40d5-ac45-e2152c2701b0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function FQDN doesn't match: passed 2, should be 0: In scope SELECT fullHostName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:43.469277 [ 6609 ] {6b43098b-9d17-4b11-aa8a-99ad6a98b5c0} executeQuery: Code: 43. DB::Exception: First argument of function fuzzBits must be String or FixedString: In scope SELECT fuzzBits([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT fuzzBits([], []);) 2025.10.23 23:30:43.472234 [ 6609 ] {6b43098b-9d17-4b11-aa8a-99ad6a98b5c0} TCPHandler: Code: 43. DB::Exception: First argument of function fuzzBits must be String or FixedString: In scope SELECT fuzzBits([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:43.768180 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:43.814929 [ 6609 ] {7cc23d2a-fbd0-4424-9135-39231290b124} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function gcd: In scope SELECT gcd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT gcd([], []);) 2025.10.23 23:30:43.820980 [ 6609 ] {7cc23d2a-fbd0-4424-9135-39231290b124} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function gcd: In scope SELECT gcd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:43.886714 [ 3255 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:43.912785 [ 6609 ] {10947242-ac1c-454d-8606-8c6bd996f8cd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the 1 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT generateRandomStructure([], []);) 2025.10.23 23:30:43.925168 [ 6609 ] {10947242-ac1c-454d-8606-8c6bd996f8cd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the 1 argument of function generateRandomStructure, expected unsigned integer or Null: In scope SELECT generateRandomStructure([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:43.934498 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:44.022376 [ 6609 ] {90ecd091-44f8-4540-9cc5-fea63c37eac3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Array(Nothing): In scope SELECT generateSnowflakeID([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT generateSnowflakeID([], []);) 2025.10.23 23:30:44.031446 [ 6609 ] {90ecd091-44f8-4540-9cc5-fea63c37eac3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'machine_id' to function 'generateSnowflakeID'. Expected: const UInt*, got: Array(Nothing): In scope SELECT generateSnowflakeID([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:44.100045 [ 6609 ] {446ea269-b647-473c-b26c-990469772d80} executeQuery: Code: 34. DB::Exception: Number of arguments for function generateULID doesn't match: passed 2, should be 0 or 1.: In scope SELECT generateULID([], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT generateULID([], []);) 2025.10.23 23:30:44.104750 [ 6609 ] {446ea269-b647-473c-b26c-990469772d80} TCPHandler: Code: 34. DB::Exception: Number of arguments for function generateULID doesn't match: passed 2, should be 0 or 1.: In scope SELECT generateULID([], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.10.23 23:30:44.139985 [ 3257 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:44.178495 [ 6609 ] {0a83912f-4350-4e34-b36d-c6467a07ea5c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT generateUUIDv4([], []);) 2025.10.23 23:30:44.182398 [ 6609 ] {0a83912f-4350-4e34-b36d-c6467a07ea5c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv4'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv4([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:44.243810 [ 6609 ] {7a8fe4fe-e6b3-406f-8593-b4c1fc3e8c01} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT generateUUIDv7([], []);) 2025.10.23 23:30:44.247394 [ 6609 ] {7a8fe4fe-e6b3-406f-8593-b4c1fc3e8c01} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'generateUUIDv7'. Expected 1 optional argument, got 2 arguments: In scope SELECT generateUUIDv7([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:44.335800 [ 6609 ] {20186d9b-7fc7-48fd-8f09-843f031d9f08} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT geoDistance([], []);) 2025.10.23 23:30:44.339794 [ 6609 ] {20186d9b-7fc7-48fd-8f09-843f031d9f08} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoDistance doesn't match: passed 2, should be 4: In scope SELECT geoDistance([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:44.418072 [ 6609 ] {d9759267-cfac-460a-a9d0-f22e29870dac} executeQuery: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT geoToH3([], []);) 2025.10.23 23:30:44.430520 [ 6609 ] {d9759267-cfac-460a-a9d0-f22e29870dac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geoToH3 doesn't match: passed 2, should be 3: In scope SELECT geoToH3([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:44.510155 [ 6609 ] {d8e2d561-850d-4f19-9a72-f735e791ee85} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of function geoToS2. Must be Float64: In scope SELECT geoToS2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT geoToS2([], []);) 2025.10.23 23:30:44.520096 [ 6609 ] {d8e2d561-850d-4f19-9a72-f735e791ee85} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of function geoToS2. Must be Float64: In scope SELECT geoToS2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:44.666059 [ 6609 ] {07406540-2446-4ded-818c-c02465a784e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT geohashDecode([], []);) 2025.10.23 23:30:44.694369 [ 6609 ] {07406540-2446-4ded-818c-c02465a784e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashDecode doesn't match: passed 2, should be 1: In scope SELECT geohashDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:44.793148 [ 6609 ] {b3663b1a-0915-46ef-80ce-5b8d987149a1} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitude' to function 'geohashEncode'. Expected: Float*, got: Array(Nothing): In scope SELECT geohashEncode([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT geohashEncode([], []);) 2025.10.23 23:30:44.799740 [ 6609 ] {b3663b1a-0915-46ef-80ce-5b8d987149a1} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'longitude' to function 'geohashEncode'. Expected: Float*, got: Array(Nothing): In scope SELECT geohashEncode([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:44.856978 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:44.891764 [ 3277 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:44.903994 [ 6609 ] {e84a4013-c671-4091-9ce2-3e412ae74cc8} executeQuery: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT geohashesInBox([], []);) 2025.10.23 23:30:44.909719 [ 6609 ] {e84a4013-c671-4091-9ce2-3e412ae74cc8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function geohashesInBox doesn't match: passed 2, should be 5: In scope SELECT geohashesInBox([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:44.967962 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:45.004047 [ 6609 ] {1df8c214-03a9-47f1-8668-152aa1d5e237} executeQuery: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT getClientHTTPHeader([], []);) 2025.10.23 23:30:45.009530 [ 6609 ] {1df8c214-03a9-47f1-8668-152aa1d5e237} TCPHandler: Code: 446. DB::Exception: The function getClientHTTPHeader requires setting `allow_get_client_http_header` to be enabled. (FUNCTION_NOT_ALLOWED) 2025.10.23 23:30:45.093472 [ 6609 ] {7f960d11-605d-45c6-bda3-9b69ab36e43e} executeQuery: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT getMacro([], []);) 2025.10.23 23:30:45.104316 [ 6609 ] {7f960d11-605d-45c6-bda3-9b69ab36e43e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getMacro doesn't match: passed 2, should be 1: In scope SELECT getMacro([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:45.141991 [ 3282 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:45.197768 [ 6609 ] {28677027-57d9-4b89-8188-1c2e0a1e01cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT getOSKernelVersion([], []);) 2025.10.23 23:30:45.201371 [ 6609 ] {28677027-57d9-4b89-8188-1c2e0a1e01cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getOSKernelVersion doesn't match: passed 2, should be 0: In scope SELECT getOSKernelVersion([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:45.245770 [ 6609 ] {27e8c016-98f0-4aa4-b979-98aa8925fdd4} executeQuery: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT getServerPort([], []);) 2025.10.23 23:30:45.249639 [ 6609 ] {27e8c016-98f0-4aa4-b979-98aa8925fdd4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getServerPort doesn't match: passed 2, should be 1: In scope SELECT getServerPort([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:45.295796 [ 6609 ] {36f3fe5c-9cb1-49d5-8e53-1714876df8ae} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT getSetting([], []);) 2025.10.23 23:30:45.302219 [ 6609 ] {36f3fe5c-9cb1-49d5-8e53-1714876df8ae} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSetting doesn't match: passed 2, should be 1: In scope SELECT getSetting([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:45.342156 [ 6609 ] {d3eebc71-8d8c-477d-b9f0-890ad41e86ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT getSizeOfEnumType([], []);) 2025.10.23 23:30:45.346910 [ 6609 ] {d3eebc71-8d8c-477d-b9f0-890ad41e86ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getSizeOfEnumType doesn't match: passed 2, should be 1: In scope SELECT getSizeOfEnumType([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:45.400553 [ 6609 ] {81d8fc40-3f54-478d-a551-0c633e9b9bce} executeQuery: Code: 44. DB::Exception: The second argument of function getSubcolumn should be a constant string with the name of a subcolumn: In scope SELECT getSubcolumn([], []). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT getSubcolumn([], []);) 2025.10.23 23:30:45.404249 [ 6609 ] {81d8fc40-3f54-478d-a551-0c633e9b9bce} TCPHandler: Code: 44. DB::Exception: The second argument of function getSubcolumn should be a constant string with the name of a subcolumn: In scope SELECT getSubcolumn([], []). (ILLEGAL_COLUMN) 2025.10.23 23:30:45.501492 [ 6609 ] {e3448f66-9eb1-4064-b4d0-00b1f632a88b} executeQuery: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT getTypeSerializationStreams([], []);) 2025.10.23 23:30:45.508505 [ 6609 ] {e3448f66-9eb1-4064-b4d0-00b1f632a88b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function getTypeSerializationStreams doesn't match: passed 2, should be 1: In scope SELECT getTypeSerializationStreams([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:45.759143 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:45.893716 [ 2791 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:45.944864 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:45.991471 [ 4227 ] {7bf2c2c7-d5e2-405c-baf4-cb9bd1c7accb} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:46.003065 [ 4227 ] {7bf2c2c7-d5e2-405c-baf4-cb9bd1c7accb} DDLWorker(test_1_repl_01111_13): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_13.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:46.019288 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:46.026952 [ 4227 ] {} DDLWorker(test_1_repl_01111_13): Unexpected error (11 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:46.144283 [ 2792 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:46.621348 [ 6609 ] {394746b0-7e2e-4836-948e-d481fcae4256} executeQuery: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT globalVariable([], []);) 2025.10.23 23:30:46.631027 [ 6609 ] {394746b0-7e2e-4836-948e-d481fcae4256} TCPHandler: Code: 42. DB::Exception: Number of arguments for function globalVariable doesn't match: passed 2, should be 1: In scope SELECT globalVariable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:46.734769 [ 6609 ] {1ecffa1e-e751-47bc-8c0b-a8edb895d933} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT greatCircleAngle([], []);) 2025.10.23 23:30:46.739469 [ 6609 ] {1ecffa1e-e751-47bc-8c0b-a8edb895d933} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleAngle doesn't match: passed 2, should be 4: In scope SELECT greatCircleAngle([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:46.809849 [ 6609 ] {df35682e-6e16-471a-b3b0-b729baa78e5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT greatCircleDistance([], []);) 2025.10.23 23:30:46.820076 [ 6609 ] {df35682e-6e16-471a-b3b0-b729baa78e5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function greatCircleDistance doesn't match: passed 2, should be 4: In scope SELECT greatCircleDistance([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:46.895691 [ 2799 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:46.969907 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:46.989701 [ 3495 ] {08065e98-e432-4a31-bf25-06e5795b255a} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:46.993726 [ 3495 ] {08065e98-e432-4a31-bf25-06e5795b255a} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:47.007284 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (11 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:47.092667 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:47.146614 [ 2805 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:47.324567 [ 6609 ] {7d178b45-3a93-4a1b-b272-b9590bcd568e} executeQuery: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupArray([], []);) 2025.10.23 23:30:47.329041 [ 6609 ] {7d178b45-3a93-4a1b-b272-b9590bcd568e} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:47.421012 [ 6609 ] {b6e60924-a742-4107-b823-316e5c3f1503} executeQuery: Code: 43. DB::Exception: Second argument of aggregate function groupArrayInsertAt must be unsigned integer. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupArrayInsertAt([], []);) 2025.10.23 23:30:47.423605 [ 6609 ] {b6e60924-a742-4107-b823-316e5c3f1503} TCPHandler: Code: 43. DB::Exception: Second argument of aggregate function groupArrayInsertAt must be unsigned integer. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:47.437019 [ 8267 ] {27b900fc-96f2-442d-a8a1-ea77ede6ce3f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:52282) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:47.439517 [ 8267 ] {27b900fc-96f2-442d-a8a1-ea77ede6ce3f} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:47.508594 [ 6609 ] {02385794-9f97-48de-b6a7-458469e03cb3} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupArrayIntersect([], []);) 2025.10.23 23:30:47.517810 [ 6609 ] {02385794-9f97-48de-b6a7-458469e03cb3} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayIntersect requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:47.638485 [ 6609 ] {f8ea6ce0-f2ec-448c-ba61-c1ac99619d4f} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupArrayLast([], []);) 2025.10.23 23:30:47.651311 [ 6609 ] {f8ea6ce0-f2ec-448c-ba61-c1ac99619d4f} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:47.767403 [ 6609 ] {2e4c5709-340a-43ff-b821-1611691990e0} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupArrayMovingAvg([], []);) 2025.10.23 23:30:47.773431 [ 6609 ] {2e4c5709-340a-43ff-b821-1611691990e0} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingAvg requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:47.897772 [ 2812 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:47.899844 [ 6609 ] {605a6012-35c0-462b-951f-7e4837fb06cd} executeQuery: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupArrayMovingSum([], []);) 2025.10.23 23:30:47.909035 [ 6609 ] {605a6012-35c0-462b-951f-7e4837fb06cd} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArrayMovingSum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:47.981063 [ 6609 ] {51fa74ad-c183-4d81-91ee-ce46cc2aa8b8} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupArraySample([], []);) 2025.10.23 23:30:47.989523 [ 6609 ] {51fa74ad-c183-4d81-91ee-ce46cc2aa8b8} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySample requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:48.006301 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:48.125982 [ 6609 ] {f3b513f2-03bf-43e3-8137-c94fbcafa801} executeQuery: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupArraySorted([], []);) 2025.10.23 23:30:48.137403 [ 6609 ] {f3b513f2-03bf-43e3-8137-c94fbcafa801} TCPHandler: Code: 42. DB::Exception: Aggregate function groupArraySorted requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:48.148966 [ 2817 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:48.177474 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:48.273957 [ 6609 ] {6a8fca53-c999-43f9-986e-5ce083d937dc} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupBitAnd([], []);) 2025.10.23 23:30:48.279699 [ 6609 ] {6a8fca53-c999-43f9-986e-5ce083d937dc} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:48.391545 [ 6609 ] {869fcff2-6d5f-4cfc-a628-d7ce358ec06a} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupBitOr([], []);) 2025.10.23 23:30:48.396599 [ 6609 ] {869fcff2-6d5f-4cfc-a628-d7ce358ec06a} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:48.475016 [ 6609 ] {2a840886-9805-4dbb-a82e-dbe8d832fdff} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupBitXor([], []);) 2025.10.23 23:30:48.486478 [ 6609 ] {2a840886-9805-4dbb-a82e-dbe8d832fdff} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:48.547037 [ 6609 ] {dbae9327-8b73-407d-ae82-8e5b00a477ae} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupBitmap([], []);) 2025.10.23 23:30:48.551381 [ 6609 ] {dbae9327-8b73-407d-ae82-8e5b00a477ae} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmap requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:48.664115 [ 6609 ] {08408b4b-6f1a-4c09-863c-13bbc3187d4b} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupBitmapAnd([], []);) 2025.10.23 23:30:48.715481 [ 6609 ] {08408b4b-6f1a-4c09-863c-13bbc3187d4b} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapAnd requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:48.854786 [ 6609 ] {868fe6ad-2b25-4b37-ab64-6bd30f6e7ba8} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupBitmapOr([], []);) 2025.10.23 23:30:48.869279 [ 6609 ] {868fe6ad-2b25-4b37-ab64-6bd30f6e7ba8} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapOr requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:48.900117 [ 2831 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:49.029525 [ 6609 ] {ef19991a-9497-4afd-a4e4-01d4fa8cf7d0} executeQuery: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupBitmapXor([], []);) 2025.10.23 23:30:49.047546 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:49.057058 [ 6609 ] {ef19991a-9497-4afd-a4e4-01d4fa8cf7d0} TCPHandler: Code: 42. DB::Exception: Aggregate function groupBitmapXor requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:49.152082 [ 2825 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:49.167938 [ 6609 ] {fb1a5e3c-c5ba-412f-b974-f3f4daddbe15} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupConcat([], []);) 2025.10.23 23:30:49.171843 [ 6609 ] {fb1a5e3c-c5ba-412f-b974-f3f4daddbe15} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:49.204533 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:49.269111 [ 6609 ] {cb984990-620f-4e18-af78-e3f469e95a01} executeQuery: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT groupUniqArray([], []);) 2025.10.23 23:30:49.281189 [ 6609 ] {cb984990-620f-4e18-af78-e3f469e95a01} TCPHandler: Code: 42. DB::Exception: Aggregate function groupUniqArray requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:49.341221 [ 6609 ] {db328fab-f393-49a4-8462-846fb9337b08} executeQuery: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT group_concat([], []);) 2025.10.23 23:30:49.352759 [ 6609 ] {db328fab-f393-49a4-8462-846fb9337b08} TCPHandler: Code: 42. DB::Exception: Aggregate function groupConcat requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:49.450642 [ 4203 ] {d9ce3d2c-c520-4d81-afac-abedfdceb4ec} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46796) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:49.466756 [ 4203 ] {d9ce3d2c-c520-4d81-afac-abedfdceb4ec} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:49.483179 [ 6609 ] {58bfb599-750b-45ea-ac80-82c4b7481741} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3CellAreaM2([], []);) 2025.10.23 23:30:49.485920 [ 6609 ] {58bfb599-750b-45ea-ac80-82c4b7481741} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaM2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:49.582120 [ 6609 ] {393d73a0-aff1-4923-b3d7-9ce1a6248458} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3CellAreaRads2([], []);) 2025.10.23 23:30:49.590414 [ 6609 ] {393d73a0-aff1-4923-b3d7-9ce1a6248458} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3CellAreaRads2 doesn't match: passed 2, should be 1: In scope SELECT h3CellAreaRads2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:49.729515 [ 6609 ] {bc48a1ba-70b3-4746-8c49-1cc563ed3fb8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3Distance. Must be UInt64: In scope SELECT h3Distance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3Distance([], []);) 2025.10.23 23:30:49.738013 [ 6609 ] {bc48a1ba-70b3-4746-8c49-1cc563ed3fb8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3Distance. Must be UInt64: In scope SELECT h3Distance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:49.902037 [ 2841 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:49.961490 [ 6609 ] {2ea7041a-9647-4a45-a3b8-e22c3ea787a1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3EdgeAngle([], []);) 2025.10.23 23:30:49.971423 [ 6609 ] {2ea7041a-9647-4a45-a3b8-e22c3ea787a1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeAngle doesn't match: passed 2, should be 1: In scope SELECT h3EdgeAngle([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:50.073865 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:50.143035 [ 6609 ] {0adef323-2dd1-4d76-b285-6a9ae96c3817} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3EdgeLengthKm([], []);) 2025.10.23 23:30:50.174343 [ 6609 ] {0adef323-2dd1-4d76-b285-6a9ae96c3817} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthKm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:50.174427 [ 4049 ] {61abb2ce-7e4b-457a-bf35-7904477e7a64} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46814) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:30:50.186435 [ 4049 ] {61abb2ce-7e4b-457a-bf35-7904477e7a64} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:30:50.243077 [ 2843 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:50.243833 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:50.292838 [ 6609 ] {fc49cbfa-10b8-4556-abff-51c7d1fa2319} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3EdgeLengthM([], []);) 2025.10.23 23:30:50.298519 [ 6609 ] {fc49cbfa-10b8-4556-abff-51c7d1fa2319} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3EdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3EdgeLengthM([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:50.353681 [ 3392 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {925e7f92-761d-4ac7-89dc-ee5b4ebf568e::202510_1_40_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:50.380405 [ 6609 ] {f6a2df3d-a0ae-4824-bb23-f508e90068e1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ExactEdgeLengthKm([], []);) 2025.10.23 23:30:50.386594 [ 6609 ] {f6a2df3d-a0ae-4824-bb23-f508e90068e1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthKm doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthKm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:50.406962 [ 3390 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {925e7f92-761d-4ac7-89dc-ee5b4ebf568e::202510_1_40_8}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:50.483662 [ 6609 ] {f5610b71-7797-4f0b-8e97-78979d8b8522} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ExactEdgeLengthM([], []);) 2025.10.23 23:30:50.490477 [ 6609 ] {f5610b71-7797-4f0b-8e97-78979d8b8522} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthM doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthM([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:50.674827 [ 6609 ] {542337ad-2987-43dd-9536-866b0bbf68fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ExactEdgeLengthRads([], []);) 2025.10.23 23:30:50.689854 [ 6609 ] {542337ad-2987-43dd-9536-866b0bbf68fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ExactEdgeLengthRads doesn't match: passed 2, should be 1: In scope SELECT h3ExactEdgeLengthRads([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:50.841154 [ 6609 ] {dea82730-69b9-4e57-b332-892abe70be2d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetBaseCell([], []);) 2025.10.23 23:30:50.868519 [ 3620 ] {} DDLWorker(test_1_repl_01111_6): Error on initialization of test_1_repl_01111_6: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:50.872360 [ 6609 ] {dea82730-69b9-4e57-b332-892abe70be2d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetBaseCell doesn't match: passed 2, should be 1: In scope SELECT h3GetBaseCell([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:50.907838 [ 2865 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:51.031056 [ 6609 ] {e81abe3d-911c-48db-885f-0aca2e174b51} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetDestinationIndexFromUnidirectionalEdge([], []);) 2025.10.23 23:30:51.036729 [ 6609 ] {e81abe3d-911c-48db-885f-0aca2e174b51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetDestinationIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetDestinationIndexFromUnidirectionalEdge([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:51.109339 [ 6609 ] {1e3d6db6-6776-4514-9528-a53adc076a70} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetFaces([], []);) 2025.10.23 23:30:51.119495 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:51.123585 [ 6609 ] {1e3d6db6-6776-4514-9528-a53adc076a70} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetFaces doesn't match: passed 2, should be 1: In scope SELECT h3GetFaces([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:51.244782 [ 6609 ] {097bf6b9-d9bb-4f8b-b71d-8066992c02ea} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetIndexesFromUnidirectionalEdge([], []);) 2025.10.23 23:30:51.246453 [ 2870 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:51.260280 [ 6609 ] {097bf6b9-d9bb-4f8b-b71d-8066992c02ea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetIndexesFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetIndexesFromUnidirectionalEdge([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:51.304945 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:51.362602 [ 6609 ] {da03d29b-2fc9-4c14-b670-5246d4d5aaea} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetOriginIndexFromUnidirectionalEdge([], []);) 2025.10.23 23:30:51.393282 [ 6609 ] {da03d29b-2fc9-4c14-b670-5246d4d5aaea} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetOriginIndexFromUnidirectionalEdge doesn't match: passed 2, should be 1: In scope SELECT h3GetOriginIndexFromUnidirectionalEdge([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:51.499101 [ 6609 ] {9a5530a2-4ca0-4574-a3e1-d186903d4047} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetPentagonIndexes([], []);) 2025.10.23 23:30:51.509718 [ 6609 ] {9a5530a2-4ca0-4574-a3e1-d186903d4047} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetPentagonIndexes doesn't match: passed 2, should be 1: In scope SELECT h3GetPentagonIndexes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:51.626833 [ 6609 ] {cbc26409-a3ae-48e3-b069-38d17bf8acc7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetRes0Indexes([], []);) 2025.10.23 23:30:51.638646 [ 6609 ] {cbc26409-a3ae-48e3-b069-38d17bf8acc7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetRes0Indexes doesn't match: passed 2, should be 0: In scope SELECT h3GetRes0Indexes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:51.710085 [ 6609 ] {1c6b749b-39e6-45b5-8711-d48a1591b204} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetResolution([], []);) 2025.10.23 23:30:51.715746 [ 6609 ] {1c6b749b-39e6-45b5-8711-d48a1591b204} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetResolution doesn't match: passed 2, should be 1: In scope SELECT h3GetResolution([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:51.846830 [ 6609 ] {8b501050-a9b7-4804-a465-31ef7e77d692} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetUnidirectionalEdge([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetUnidirectionalEdge([], []);) 2025.10.23 23:30:51.855313 [ 6609 ] {8b501050-a9b7-4804-a465-31ef7e77d692} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3GetUnidirectionalEdge. Must be UInt64: In scope SELECT h3GetUnidirectionalEdge([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:51.911934 [ 2883 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:51.955215 [ 6609 ] {68e66ca9-a0fa-4487-a79c-899b3f97a79d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetUnidirectionalEdgeBoundary([], []);) 2025.10.23 23:30:51.970586 [ 6609 ] {68e66ca9-a0fa-4487-a79c-899b3f97a79d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgeBoundary doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgeBoundary([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.071256 [ 6609 ] {e9364973-f53b-4c2d-98b8-b076837b354c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3GetUnidirectionalEdgesFromHexagon([], []);) 2025.10.23 23:30:52.077871 [ 6609 ] {e9364973-f53b-4c2d-98b8-b076837b354c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3GetUnidirectionalEdgesFromHexagon doesn't match: passed 2, should be 1: In scope SELECT h3GetUnidirectionalEdgesFromHexagon([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.153770 [ 6609 ] {6e99cdf3-0444-48fc-8e05-6561c90c2f94} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3HexAreaKm2([], []);) 2025.10.23 23:30:52.162301 [ 6609 ] {6e99cdf3-0444-48fc-8e05-6561c90c2f94} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaKm2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaKm2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.195491 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:52.248618 [ 2891 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:52.258384 [ 6609 ] {5e427e6e-80a8-4871-970a-4dde36df4d45} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3HexAreaM2([], []);) 2025.10.23 23:30:52.268283 [ 6609 ] {5e427e6e-80a8-4871-970a-4dde36df4d45} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3HexAreaM2 doesn't match: passed 2, should be 1: In scope SELECT h3HexAreaM2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.344072 [ 6609 ] {2f11cb89-37a5-4e28-9cb9-b25bf1f0460a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3HexRing. Must be UInt64: In scope SELECT h3HexRing([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3HexRing([], []);) 2025.10.23 23:30:52.347335 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:52.348050 [ 6609 ] {2f11cb89-37a5-4e28-9cb9-b25bf1f0460a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3HexRing. Must be UInt64: In scope SELECT h3HexRing([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:52.443349 [ 6609 ] {6f9996b8-fc36-4637-9485-31e757c9aa83} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3IndexesAreNeighbors. Must be UInt64: In scope SELECT h3IndexesAreNeighbors([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3IndexesAreNeighbors([], []);) 2025.10.23 23:30:52.450492 [ 6609 ] {6f9996b8-fc36-4637-9485-31e757c9aa83} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3IndexesAreNeighbors. Must be UInt64: In scope SELECT h3IndexesAreNeighbors([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:52.492430 [ 6609 ] {f042ad5c-478c-4e33-a7a0-1a84e35656c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3IsPentagon([], []);) 2025.10.23 23:30:52.496286 [ 6609 ] {f042ad5c-478c-4e33-a7a0-1a84e35656c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsPentagon doesn't match: passed 2, should be 1: In scope SELECT h3IsPentagon([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.539669 [ 6609 ] {e552ea95-8656-4378-83d4-8ace68a69855} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3IsResClassIII([], []);) 2025.10.23 23:30:52.543515 [ 6609 ] {e552ea95-8656-4378-83d4-8ace68a69855} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsResClassIII doesn't match: passed 2, should be 1: In scope SELECT h3IsResClassIII([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.692390 [ 6609 ] {03df4a8e-bb16-4392-b63d-9473457af8b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3IsValid([], []);) 2025.10.23 23:30:52.695145 [ 6609 ] {03df4a8e-bb16-4392-b63d-9473457af8b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3IsValid doesn't match: passed 2, should be 1: In scope SELECT h3IsValid([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.747010 [ 6609 ] {0ea443a1-1c5c-4506-8348-a4a9e757b6d2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3Line. Must be UInt64: In scope SELECT h3Line([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3Line([], []);) 2025.10.23 23:30:52.754550 [ 6609 ] {0ea443a1-1c5c-4506-8348-a4a9e757b6d2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3Line. Must be UInt64: In scope SELECT h3Line([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:52.778821 [ 3495 ] {5d21ae32-8444-449b-a973-01629f289b4c} executeQuery: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:30:52.784003 [ 3495 ] {5d21ae32-8444-449b-a973-01629f289b4c} DDLWorker(test_1_repl_01111_8): Query /* ddl_entry=query-0000000009 */ CREATE TABLE test_1_repl_01111_8.rmt_32540_551_30592 UUID 'b91557de-758b-47a2-8f05-f9d4669532dd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:52.797357 [ 3495 ] {} DDLWorker(test_1_repl_01111_8): Unexpected error (12 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/b91/b91557de-758b-47a2-8f05-f9d4669532dd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:52.807752 [ 6609 ] {14cbe409-2abf-4a7c-b1d8-04e650a7006c} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3NumHexagons([], []);) 2025.10.23 23:30:52.811918 [ 6609 ] {14cbe409-2abf-4a7c-b1d8-04e650a7006c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3NumHexagons doesn't match: passed 2, should be 1: In scope SELECT h3NumHexagons([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.818956 [ 2904 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:52.892832 [ 6609 ] {14aeca49-0b0a-41ed-82c7-ab746c32eb72} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3PointDistKm([], []);) 2025.10.23 23:30:52.904258 [ 6609 ] {14aeca49-0b0a-41ed-82c7-ab746c32eb72} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistKm doesn't match: passed 2, should be 4: In scope SELECT h3PointDistKm([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:52.913931 [ 2908 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:52.918323 [ 9673 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:30:57: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:53.011521 [ 6609 ] {1d28c45a-9f12-48fa-8e39-fca9f8ec09c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3PointDistM([], []);) 2025.10.23 23:30:53.026968 [ 6609 ] {1d28c45a-9f12-48fa-8e39-fca9f8ec09c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistM doesn't match: passed 2, should be 4: In scope SELECT h3PointDistM([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:53.138593 [ 6609 ] {8ecb0492-62b5-4c97-99d6-06931f0e6633} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3PointDistRads([], []);) 2025.10.23 23:30:53.150073 [ 6609 ] {8ecb0492-62b5-4c97-99d6-06931f0e6633} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3PointDistRads doesn't match: passed 2, should be 4: In scope SELECT h3PointDistRads([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:53.202621 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:53.250701 [ 2910 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:53.281105 [ 6609 ] {ac4fdcc0-d53f-4cfe-8b35-48432caafe5a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToCenterChild. Must be UInt64: In scope SELECT h3ToCenterChild([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ToCenterChild([], []);) 2025.10.23 23:30:53.283824 [ 6609 ] {ac4fdcc0-d53f-4cfe-8b35-48432caafe5a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToCenterChild. Must be UInt64: In scope SELECT h3ToCenterChild([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:53.344553 [ 6609 ] {c0b41b98-49ab-4bf6-8047-85dc13c32260} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToChildren. Must be UInt64: In scope SELECT h3ToChildren([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ToChildren([], []);) 2025.10.23 23:30:53.348408 [ 6609 ] {c0b41b98-49ab-4bf6-8047-85dc13c32260} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToChildren. Must be UInt64: In scope SELECT h3ToChildren([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:53.398404 [ 6609 ] {f1a32c85-c416-4e2b-918c-d129191987d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ToGeo([], []);) 2025.10.23 23:30:53.412027 [ 6609 ] {f1a32c85-c416-4e2b-918c-d129191987d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeo doesn't match: passed 2, should be 1: In scope SELECT h3ToGeo([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:53.455126 [ 6609 ] {396c2a22-6e40-4570-9b5a-92c88fd8eccb} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ToGeoBoundary([], []);) 2025.10.23 23:30:53.459066 [ 6609 ] {396c2a22-6e40-4570-9b5a-92c88fd8eccb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToGeoBoundary doesn't match: passed 2, should be 1: In scope SELECT h3ToGeoBoundary([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:53.474745 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:53.526872 [ 6609 ] {56278069-3859-4a0c-a589-5955030f1390} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToParent. Must be UInt64: In scope SELECT h3ToParent([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ToParent([], []);) 2025.10.23 23:30:53.537886 [ 6609 ] {56278069-3859-4a0c-a589-5955030f1390} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3ToParent. Must be UInt64: In scope SELECT h3ToParent([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:53.621546 [ 6609 ] {bb4374a9-fd91-422e-86c4-47f6a4b6b92d} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3ToString([], []);) 2025.10.23 23:30:53.625766 [ 6609 ] {bb4374a9-fd91-422e-86c4-47f6a4b6b92d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3ToString doesn't match: passed 2, should be 1: In scope SELECT h3ToString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:53.667539 [ 6609 ] {8a1bad1d-3561-4747-9e2c-2e5a3233e373} executeQuery: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3UnidirectionalEdgeIsValid([], []);) 2025.10.23 23:30:53.716217 [ 6609 ] {8a1bad1d-3561-4747-9e2c-2e5a3233e373} TCPHandler: Code: 42. DB::Exception: Number of arguments for function h3UnidirectionalEdgeIsValid doesn't match: passed 2, should be 1: In scope SELECT h3UnidirectionalEdgeIsValid([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:53.764265 [ 6609 ] {47f77e55-74b2-4581-99ca-7a0ff423a6f2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3kRing. Must be UInt64: In scope SELECT h3kRing([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT h3kRing([], []);) 2025.10.23 23:30:53.772469 [ 6609 ] {47f77e55-74b2-4581-99ca-7a0ff423a6f2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function h3kRing. Must be UInt64: In scope SELECT h3kRing([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:53.820806 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:53.916162 [ 2926 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:54.252949 [ 2930 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:54.308765 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:54.464848 [ 6609 ] {8e0e6ec5-9bcb-472c-8167-320bca8b3539} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasColumnInTable([], []);) 2025.10.23 23:30:54.468954 [ 6609 ] {8e0e6ec5-9bcb-472c-8167-320bca8b3539} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function hasColumnInTable: In scope SELECT hasColumnInTable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:54.487399 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:54.587363 [ 6609 ] {62a8c00e-4255-43ea-8ef2-c91f2139d931} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasSubsequence: In scope SELECT hasSubsequence([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasSubsequence([], []);) 2025.10.23 23:30:54.589707 [ 6609 ] {62a8c00e-4255-43ea-8ef2-c91f2139d931} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasSubsequence: In scope SELECT hasSubsequence([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:54.634618 [ 6609 ] {1f97eb4f-4f10-4e78-ae56-1e7a54737f40} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasSubsequenceCaseInsensitive: In scope SELECT hasSubsequenceCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasSubsequenceCaseInsensitive([], []);) 2025.10.23 23:30:54.638108 [ 6609 ] {1f97eb4f-4f10-4e78-ae56-1e7a54737f40} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasSubsequenceCaseInsensitive: In scope SELECT hasSubsequenceCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:54.744852 [ 6609 ] {61771a3d-b677-4462-9f91-62553ca43a73} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasSubsequenceCaseInsensitiveUTF8: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasSubsequenceCaseInsensitiveUTF8([], []);) 2025.10.23 23:30:54.749171 [ 6609 ] {61771a3d-b677-4462-9f91-62553ca43a73} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasSubsequenceCaseInsensitiveUTF8: In scope SELECT hasSubsequenceCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:54.793737 [ 6609 ] {a79f0892-7596-4754-b866-dd02be999517} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasSubsequenceUTF8: In scope SELECT hasSubsequenceUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasSubsequenceUTF8([], []);) 2025.10.23 23:30:54.799833 [ 6609 ] {a79f0892-7596-4754-b866-dd02be999517} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasSubsequenceUTF8: In scope SELECT hasSubsequenceUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:54.822961 [ 2942 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:54.918864 [ 2944 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:55.238097 [ 6609 ] {1e111688-7f2e-4bbc-b2f0-4a98ce78a8fc} executeQuery: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasThreadFuzzer([], []);) 2025.10.23 23:30:55.255206 [ 6609 ] {1e111688-7f2e-4bbc-b2f0-4a98ce78a8fc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hasThreadFuzzer doesn't match: passed 2, should be 0: In scope SELECT hasThreadFuzzer([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:55.255975 [ 2951 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:55.350079 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:55.397017 [ 6609 ] {18b5a5cf-dfce-487d-8231-f5522d5b2869} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasToken: In scope SELECT hasToken([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasToken([], []);) 2025.10.23 23:30:55.407777 [ 6609 ] {18b5a5cf-dfce-487d-8231-f5522d5b2869} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasToken: In scope SELECT hasToken([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:55.558472 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:55.612882 [ 6609 ] {df9d6dcc-2fbc-4379-8949-d3e18ae58707} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasTokenCaseInsensitive: In scope SELECT hasTokenCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasTokenCaseInsensitive([], []);) 2025.10.23 23:30:55.700716 [ 6609 ] {df9d6dcc-2fbc-4379-8949-d3e18ae58707} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasTokenCaseInsensitive: In scope SELECT hasTokenCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:55.747799 [ 6609 ] {165097b3-442a-443c-89c4-25b550fa0962} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasTokenCaseInsensitiveOrNull: In scope SELECT hasTokenCaseInsensitiveOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasTokenCaseInsensitiveOrNull([], []);) 2025.10.23 23:30:55.756506 [ 6609 ] {165097b3-442a-443c-89c4-25b550fa0962} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasTokenCaseInsensitiveOrNull: In scope SELECT hasTokenCaseInsensitiveOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:55.823751 [ 6609 ] {e3d0b337-e8f7-44f5-86ae-2fec1e65682b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasTokenOrNull: In scope SELECT hasTokenOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hasTokenOrNull([], []);) 2025.10.23 23:30:55.825280 [ 2954 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:55.828189 [ 6609 ] {e3d0b337-e8f7-44f5-86ae-2fec1e65682b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hasTokenOrNull: In scope SELECT hasTokenOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:55.873329 [ 6609 ] {062270c9-c478-451d-9d8c-ea9aaa666138} executeQuery: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hex([], []);) 2025.10.23 23:30:55.877664 [ 6609 ] {062270c9-c478-451d-9d8c-ea9aaa666138} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hex doesn't match: passed 2, should be 1: In scope SELECT hex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:55.921440 [ 2955 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:55.925308 [ 6609 ] {0914aebb-79e9-43d8-ac82-b42ef358be51} executeQuery: Code: 44. DB::Exception: Illegal column type Array(Nothing) for function hilbertDecode, should be a native UInt: In scope SELECT hilbertDecode([], []). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hilbertDecode([], []);) 2025.10.23 23:30:55.932562 [ 6609 ] {0914aebb-79e9-43d8-ac82-b42ef358be51} TCPHandler: Code: 44. DB::Exception: Illegal column type Array(Nothing) for function hilbertDecode, should be a native UInt: In scope SELECT hilbertDecode([], []). (ILLEGAL_COLUMN) 2025.10.23 23:30:55.996725 [ 6609 ] {0d0df72d-523e-4be8-a0d5-7f1596e7d7c2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hilbertEncode([], []);) 2025.10.23 23:30:56.008331 [ 6609 ] {0d0df72d-523e-4be8-a0d5-7f1596e7d7c2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function hilbertEncode, should be a native UInt: In scope SELECT hilbertEncode([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:56.118479 [ 6609 ] {a533fb3a-4d6a-46d2-b276-81164dd61761} executeQuery: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT histogram([], []);) 2025.10.23 23:30:56.126455 [ 6609 ] {a533fb3a-4d6a-46d2-b276-81164dd61761} TCPHandler: Code: 42. DB::Exception: Function histogram requires single parameter: bins count. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:56.258404 [ 2963 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:56.314320 [ 6609 ] {f2011556-4cd1-4795-aec3-35a1db9688b9} executeQuery: Code: 48. DB::Exception: Hive hash is not combineable for multiple arguments: In scope SELECT hiveHash([], []). (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hiveHash([], []);) 2025.10.23 23:30:56.328435 [ 6609 ] {f2011556-4cd1-4795-aec3-35a1db9688b9} TCPHandler: Code: 48. DB::Exception: Hive hash is not combineable for multiple arguments: In scope SELECT hiveHash([], []). (NOT_IMPLEMENTED) 2025.10.23 23:30:56.431992 [ 6609 ] {03dbbef3-46bb-459e-8fed-4eda1c656182} executeQuery: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 2, should be 3 or 4: In scope SELECT hop([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hop([], []);) 2025.10.23 23:30:56.448088 [ 6609 ] {03dbbef3-46bb-459e-8fed-4eda1c656182} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hop doesn't match: passed 2, should be 3 or 4: In scope SELECT hop([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:56.488139 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:56.604458 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:56.640907 [ 6609 ] {a25fa269-df67-4b81-b3f0-0b2da9d0bbe4} executeQuery: Code: 42. DB::Exception: Number of arguments for function hopEnd doesn't match: passed 2, should be 3 or 4: In scope SELECT hopEnd([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hopEnd([], []);) 2025.10.23 23:30:56.650988 [ 6609 ] {a25fa269-df67-4b81-b3f0-0b2da9d0bbe4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hopEnd doesn't match: passed 2, should be 3 or 4: In scope SELECT hopEnd([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:56.717945 [ 6609 ] {bb58fb22-d9c2-410b-b43d-3e462b8644fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function hopStart doesn't match: passed 2, should be 3 or 4: In scope SELECT hopStart([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hopStart([], []);) 2025.10.23 23:30:56.721952 [ 6609 ] {bb58fb22-d9c2-410b-b43d-3e462b8644fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hopStart doesn't match: passed 2, should be 3 or 4: In scope SELECT hopStart([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:56.811811 [ 6609 ] {a7697428-dc80-4282-a3dd-3a1e7d57f726} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hostName([], []);) 2025.10.23 23:30:56.816521 [ 6609 ] {a7697428-dc80-4282-a3dd-3a1e7d57f726} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:56.828059 [ 2964 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:56.869580 [ 6609 ] {bb075070-0c87-4e7a-921f-0dedb0020503} executeQuery: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hostname([], []);) 2025.10.23 23:30:56.875160 [ 6609 ] {bb075070-0c87-4e7a-921f-0dedb0020503} TCPHandler: Code: 42. DB::Exception: Number of arguments for function hostName doesn't match: passed 2, should be 0: In scope SELECT hostname([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:56.924055 [ 2973 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:56.928485 [ 6609 ] {d6b44bc0-b387-499f-8738-6dc8b2592f9d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hypot: In scope SELECT hypot([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT hypot([], []);) 2025.10.23 23:30:56.936485 [ 6609 ] {d6b44bc0-b387-499f-8738-6dc8b2592f9d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function hypot: In scope SELECT hypot([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:56.990947 [ 6609 ] {3590391d-9b4c-4008-8624-f147fd9e887c} executeQuery: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT identity([], []);) 2025.10.23 23:30:56.996903 [ 6609 ] {3590391d-9b4c-4008-8624-f147fd9e887c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function identity doesn't match: passed 2, should be 1: In scope SELECT identity([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:57.128344 [ 6609 ] {47090625-1f84-4161-b81e-8c4d788db040} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT idnaDecode([], []);) 2025.10.23 23:30:57.143598 [ 6609 ] {47090625-1f84-4161-b81e-8c4d788db040} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaDecode doesn't match: passed 2, should be 1: In scope SELECT idnaDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:57.249451 [ 6609 ] {beeb4986-a98e-47dc-9ae1-122fa0a0e7ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT idnaEncode([], []);) 2025.10.23 23:30:57.255420 [ 6609 ] {beeb4986-a98e-47dc-9ae1-122fa0a0e7ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function idnaEncode doesn't match: passed 2, should be 1: In scope SELECT idnaEncode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:57.260671 [ 2976 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:57.379078 [ 6609 ] {a652113a-047d-425b-a55d-1c51a3aa98da} executeQuery: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT if([], []);) 2025.10.23 23:30:57.395142 [ 6609 ] {a652113a-047d-425b-a55d-1c51a3aa98da} TCPHandler: Code: 42. DB::Exception: Number of arguments for function if doesn't match: passed 2, should be 3: In scope SELECT if([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:57.515431 [ 6609 ] {ee66ca03-ac40-4d53-adfd-36c0a8797c70} executeQuery: Code: 43. DB::Exception: Argument for function isFinite must be a number: In scope SELECT ifNotFinite([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ifNotFinite([], []);) 2025.10.23 23:30:57.528941 [ 6609 ] {ee66ca03-ac40-4d53-adfd-36c0a8797c70} TCPHandler: Code: 43. DB::Exception: Argument for function isFinite must be a number: In scope SELECT ifNotFinite([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:57.557498 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:57.651112 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:57.830683 [ 2983 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:57.864094 [ 6609 ] {4eee6210-30d2-45d3-a3c0-40748bad5d2d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ilike: In scope SELECT [] ILIKE []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ilike([], []);) 2025.10.23 23:30:57.868871 [ 6609 ] {4eee6210-30d2-45d3-a3c0-40748bad5d2d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ilike: In scope SELECT [] ILIKE []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:57.926408 [ 2988 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:58.263069 [ 2991 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:58.612615 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:58.732800 [ 3001 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286d17dc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286d20a6 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:58.733712 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:58.748458 [ 6609 ] {3d6e82e5-de61-40e2-994a-c095b0c66bd7} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT initcap([], []);) 2025.10.23 23:30:58.754298 [ 6609 ] {3d6e82e5-de61-40e2-994a-c095b0c66bd7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcap doesn't match: passed 2, should be 1: In scope SELECT initcap([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:58.824494 [ 6609 ] {589ac9ba-e4dc-40d1-a0d2-560efc2c4657} executeQuery: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT initcapUTF8([], []);) 2025.10.23 23:30:58.829242 [ 6609 ] {589ac9ba-e4dc-40d1-a0d2-560efc2c4657} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initcapUTF8 doesn't match: passed 2, should be 1: In scope SELECT initcapUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:58.838618 [ 3004 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:58.899901 [ 6609 ] {15b0f97c-17a5-4a36-9669-6816c0f6907e} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT initialQueryID([], []);) 2025.10.23 23:30:58.905203 [ 6609 ] {15b0f97c-17a5-4a36-9669-6816c0f6907e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initialQueryID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:58.931901 [ 3005 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:58.949036 [ 6609 ] {1b1f731a-e88d-4e4f-b71e-65aeee9c3735} executeQuery: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT initial_query_id([], []);) 2025.10.23 23:30:58.968695 [ 6609 ] {1b1f731a-e88d-4e4f-b71e-65aeee9c3735} TCPHandler: Code: 42. DB::Exception: Number of arguments for function initialQueryID doesn't match: passed 2, should be 0: In scope SELECT initial_query_id([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:59.049596 [ 6609 ] {33b97336-0c01-4470-8743-f38e5e27ad4b} executeQuery: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT initializeAggregation([], []);) 2025.10.23 23:30:59.068897 [ 6609 ] {33b97336-0c01-4470-8743-f38e5e27ad4b} TCPHandler: Code: 43. DB::Exception: First argument for function initializeAggregation must be constant string: name of aggregate function.: In scope SELECT initializeAggregation([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:59.114072 [ 6609 ] {4e3483d6-f340-4f26-ba91-074f4f995250} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitive: In scope SELECT instr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT instr([], []);) 2025.10.23 23:30:59.119024 [ 6609 ] {4e3483d6-f340-4f26-ba91-074f4f995250} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitive: In scope SELECT instr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:59.192083 [ 6609 ] {3742072e-b876-4482-9a38-af59f85c95bf} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function intDiv: In scope SELECT intDiv([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT intDiv([], []);) 2025.10.23 23:30:59.197199 [ 6609 ] {3742072e-b876-4482-9a38-af59f85c95bf} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function intDiv: In scope SELECT intDiv([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:59.261669 [ 6609 ] {1c27b5bb-9191-4554-8e75-411a68c0377d} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function intDivOrZero: In scope SELECT intDivOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT intDivOrZero([], []);) 2025.10.23 23:30:59.265162 [ 3008 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:59.270206 [ 6609 ] {1c27b5bb-9191-4554-8e75-411a68c0377d} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function intDivOrZero: In scope SELECT intDivOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:59.362327 [ 6609 ] {2a5e9338-5c84-4bb0-872f-0947c6b993c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT intExp10([], []);) 2025.10.23 23:30:59.387332 [ 6609 ] {2a5e9338-5c84-4bb0-872f-0947c6b993c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp10 doesn't match: passed 2, should be 1: In scope SELECT intExp10([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:59.480194 [ 6609 ] {ec2ae2e6-ae91-4660-9175-420a39cf9e61} executeQuery: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT intExp2([], []);) 2025.10.23 23:30:59.487397 [ 6609 ] {ec2ae2e6-ae91-4660-9175-420a39cf9e61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intExp2 doesn't match: passed 2, should be 1: In scope SELECT intExp2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:59.593747 [ 6609 ] {8bfbc6ac-7934-4b9b-a850-9d4a3a54666e} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT intHash32([], []);) 2025.10.23 23:30:59.600417 [ 6609 ] {8bfbc6ac-7934-4b9b-a850-9d4a3a54666e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash32 doesn't match: passed 2, should be 1: In scope SELECT intHash32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:59.668695 [ 6609 ] {6500ef83-ea03-4735-9fc1-296f2de75193} executeQuery: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT intHash64([], []);) 2025.10.23 23:30:59.728012 [ 6609 ] {6500ef83-ea03-4735-9fc1-296f2de75193} TCPHandler: Code: 42. DB::Exception: Number of arguments for function intHash64 doesn't match: passed 2, should be 1: In scope SELECT intHash64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:30:59.758487 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:59.794718 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:30:59.805634 [ 6609 ] {e69f85fb-4057-4310-8c56-17641b8b37b6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of aggregate function intervalLengthSum, must be native integral type, Date/DateTime or Float. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT intervalLengthSum([], []);) 2025.10.23 23:30:59.814693 [ 6609 ] {e69f85fb-4057-4310-8c56-17641b8b37b6} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of aggregate function intervalLengthSum, must be native integral type, Date/DateTime or Float. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:30:59.844182 [ 3019 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:59.933861 [ 3024 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:30:59.968234 [ 6609 ] {f650d93d-05f6-419e-a0bc-6fe4439611dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isConstant([], []);) 2025.10.23 23:30:59.971354 [ 6609 ] {f650d93d-05f6-419e-a0bc-6fe4439611dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isConstant doesn't match: passed 2, should be 1: In scope SELECT isConstant([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:00.023169 [ 6609 ] {8d69e500-962a-42a4-87bf-0dc1da725da3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function isDecimalOverflow: In scope SELECT isDecimalOverflow([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isDecimalOverflow([], []);) 2025.10.23 23:31:00.027811 [ 6609 ] {8d69e500-962a-42a4-87bf-0dc1da725da3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function isDecimalOverflow: In scope SELECT isDecimalOverflow([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:00.081063 [ 6609 ] {8754a372-f94c-419b-8ca4-0aa667dc88f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isDynamicElementInSharedData([], []);) 2025.10.23 23:31:00.122728 [ 6609 ] {8754a372-f94c-419b-8ca4-0aa667dc88f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isDynamicElementInSharedData doesn't match: passed 2, should be 1: In scope SELECT isDynamicElementInSharedData([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:00.156747 [ 6609 ] {850590e3-1c1c-4d2c-86ec-b8909cf2ad8a} executeQuery: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isFinite([], []);) 2025.10.23 23:31:00.160544 [ 6609 ] {850590e3-1c1c-4d2c-86ec-b8909cf2ad8a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isFinite doesn't match: passed 2, should be 1: In scope SELECT isFinite([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:00.212139 [ 6609 ] {8cc5390a-f15a-4093-965d-4e8a300de4a2} executeQuery: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isIPAddressInRange([], []);) 2025.10.23 23:31:00.216169 [ 6609 ] {8cc5390a-f15a-4093-965d-4e8a300de4a2} TCPHandler: Code: 43. DB::Exception: The arguments of function isIPAddressInRange must be String: In scope SELECT isIPAddressInRange([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:00.267371 [ 3034 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:00.268578 [ 6609 ] {0613a15e-9b58-4fab-9bf3-6342ba5eadac} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isIPv4String([], []);) 2025.10.23 23:31:00.272237 [ 6609 ] {0613a15e-9b58-4fab-9bf3-6342ba5eadac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv4String doesn't match: passed 2, should be 1: In scope SELECT isIPv4String([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:00.327237 [ 6609 ] {064f06de-942e-4bb5-a967-1a5fbe0870f0} executeQuery: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isIPv6String([], []);) 2025.10.23 23:31:00.330905 [ 6609 ] {064f06de-942e-4bb5-a967-1a5fbe0870f0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isIPv6String doesn't match: passed 2, should be 1: In scope SELECT isIPv6String([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:00.385103 [ 6609 ] {f5ba6374-0742-45f4-aafe-57f1037213b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isInfinite([], []);) 2025.10.23 23:31:00.390339 [ 6609 ] {f5ba6374-0742-45f4-aafe-57f1037213b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isInfinite doesn't match: passed 2, should be 1: In scope SELECT isInfinite([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:00.534324 [ 6609 ] {749c1397-d364-403e-b379-60cc01cbd6ba} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isNaN([], []);) 2025.10.23 23:31:00.548107 [ 6609 ] {749c1397-d364-403e-b379-60cc01cbd6ba} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNaN doesn't match: passed 2, should be 1: In scope SELECT isNaN([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:00.681907 [ 6609 ] {60c2bdbd-39d3-41f6-9b98-6935a33d8228} executeQuery: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT [] <=> []. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isNotDistinctFrom([], []);) 2025.10.23 23:31:00.690481 [ 6609 ] {60c2bdbd-39d3-41f6-9b98-6935a33d8228} TCPHandler: Code: 48. DB::Exception: Function isNotDistinctFrom can be used only in the JOIN ON section: In scope SELECT [] <=> []. (NOT_IMPLEMENTED) 2025.10.23 23:31:00.836320 [ 6609 ] {1f968657-05ce-4102-811d-60762b157ad5} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isNotNull([], []);) 2025.10.23 23:31:00.846366 [ 3023 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:00.847547 [ 6609 ] {1f968657-05ce-4102-811d-60762b157ad5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNotNull doesn't match: passed 2, should be 1: In scope SELECT isNotNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:00.850365 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:00.938095 [ 3039 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:00.947732 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:01.015882 [ 6609 ] {f35c3175-3432-4c7b-9367-865cbad45771} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isNull([], []);) 2025.10.23 23:31:01.036384 [ 6609 ] {f35c3175-3432-4c7b-9367-865cbad45771} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNull doesn't match: passed 2, should be 1: In scope SELECT isNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:01.132452 [ 6609 ] {5c7799c4-8e77-43dd-bf94-dd558ef3c382} executeQuery: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isNullable([], []);) 2025.10.23 23:31:01.146740 [ 6609 ] {5c7799c4-8e77-43dd-bf94-dd558ef3c382} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isNullable doesn't match: passed 2, should be 1: In scope SELECT isNullable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:01.231821 [ 6609 ] {9b2da44c-f8bc-4d57-a929-b8015d96865a} executeQuery: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isValidJSON([], []);) 2025.10.23 23:31:01.238523 [ 6609 ] {9b2da44c-f8bc-4d57-a929-b8015d96865a} TCPHandler: Code: 42. DB::Exception: Function isValidJSON needs exactly one argument: In scope SELECT isValidJSON([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:01.269356 [ 3045 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:01.317842 [ 6609 ] {28d442a2-68a4-4aad-8ffc-f22cc5cade42} executeQuery: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isValidUTF8([], []);) 2025.10.23 23:31:01.324599 [ 6609 ] {28d442a2-68a4-4aad-8ffc-f22cc5cade42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT isValidUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:01.429965 [ 6609 ] {9552bf35-feff-4fe2-8976-21dc9a95a171} executeQuery: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT isZeroOrNull([], []);) 2025.10.23 23:31:01.436625 [ 6609 ] {9552bf35-feff-4fe2-8976-21dc9a95a171} TCPHandler: Code: 42. DB::Exception: Number of arguments for function isZeroOrNull doesn't match: passed 2, should be 1: In scope SELECT isZeroOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:01.615838 [ 6609 ] {fa6d703b-cffa-4895-97a3-5035a2d6f440} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function jaroSimilarity: In scope SELECT jaroSimilarity([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT jaroSimilarity([], []);) 2025.10.23 23:31:01.633872 [ 6609 ] {fa6d703b-cffa-4895-97a3-5035a2d6f440} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function jaroSimilarity: In scope SELECT jaroSimilarity([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:01.771651 [ 6609 ] {01e42648-112a-4c9d-9161-1691db59da5d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function jaroWinklerSimilarity: In scope SELECT jaroWinklerSimilarity([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT jaroWinklerSimilarity([], []);) 2025.10.23 23:31:01.784901 [ 6609 ] {01e42648-112a-4c9d-9161-1691db59da5d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function jaroWinklerSimilarity: In scope SELECT jaroWinklerSimilarity([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:01.848542 [ 3051 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:01.897150 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:01.944144 [ 3054 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:01.964359 [ 6609 ] {87b540d8-99e7-4010-8764-0c6b08eda6cc} executeQuery: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHash([], []). (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT javaHash([], []);) 2025.10.23 23:31:01.967337 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:01.997924 [ 6609 ] {87b540d8-99e7-4010-8764-0c6b08eda6cc} TCPHandler: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHash([], []). (NOT_IMPLEMENTED) 2025.10.23 23:31:02.086497 [ 6609 ] {3b6c3eb2-f9a9-422f-a554-67fc500c440d} executeQuery: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHashUTF16LE([], []). (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT javaHashUTF16LE([], []);) 2025.10.23 23:31:02.101044 [ 6609 ] {3b6c3eb2-f9a9-422f-a554-67fc500c440d} TCPHandler: Code: 48. DB::Exception: Java hash is not combineable for multiple arguments: In scope SELECT javaHashUTF16LE([], []). (NOT_IMPLEMENTED) 2025.10.23 23:31:02.272208 [ 3062 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:02.343335 [ 6609 ] {7d01e512-1291-4b16-8181-0224a6b12d9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT joinGet([], []);) 2025.10.23 23:31:02.374942 [ 6609 ] {7d01e512-1291-4b16-8181-0224a6b12d9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGet' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGet([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:02.549445 [ 6609 ] {49f541b3-728f-4844-842b-4970e5788edc} executeQuery: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT joinGetOrNull([], []);) 2025.10.23 23:31:02.588743 [ 6609 ] {49f541b3-728f-4844-842b-4970e5788edc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function 'joinGetOrNull' doesn't match: passed 2, should be greater or equal to 3: In scope SELECT joinGetOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:02.701719 [ 6609 ] {477d2a5a-b944-4f62-b220-89eb86f933eb} executeQuery: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT jsonMergePatch([], []);) 2025.10.23 23:31:02.726152 [ 6609 ] {477d2a5a-b944-4f62-b220-89eb86f933eb} TCPHandler: Code: 43. DB::Exception: Function JSONMergePatch requires string arguments: In scope SELECT jsonMergePatch([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:02.852074 [ 3066 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:02.920644 [ 6609 ] {55703bf7-35ad-43f7-818d-6ba5c4a5ce9c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function jumpConsistentHash: In scope SELECT jumpConsistentHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT jumpConsistentHash([], []);) 2025.10.23 23:31:02.932314 [ 6609 ] {55703bf7-35ad-43f7-818d-6ba5c4a5ce9c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function jumpConsistentHash: In scope SELECT jumpConsistentHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:02.946194 [ 3071 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:02.966045 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:03.034790 [ 2720 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:03.274249 [ 3080 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:03.317026 [ 6609 ] {c73ee0fd-ec29-4788-80f0-2d7b011f9cdd} executeQuery: Code: 48. DB::Exception: Aggregate function kolmogorovSmirnovTest only supports numerical types. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT kolmogorovSmirnovTest([], []);) 2025.10.23 23:31:03.322309 [ 6609 ] {c73ee0fd-ec29-4788-80f0-2d7b011f9cdd} TCPHandler: Code: 48. DB::Exception: Aggregate function kolmogorovSmirnovTest only supports numerical types. (NOT_IMPLEMENTED) 2025.10.23 23:31:03.332626 [ 4203 ] {3f8a25a7-4540-4ab2-afa2-e280ad6429eb} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37840) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_10568_29553_3589 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:03.347054 [ 4203 ] {3f8a25a7-4540-4ab2-afa2-e280ad6429eb} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:03.458245 [ 6609 ] {17bad14a-b7c6-47f8-9df8-be30f4aa98a2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function kostikConsistentHash: In scope SELECT kostikConsistentHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT kostikConsistentHash([], []);) 2025.10.23 23:31:03.470962 [ 6609 ] {17bad14a-b7c6-47f8-9df8-be30f4aa98a2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function kostikConsistentHash: In scope SELECT kostikConsistentHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:03.506998 [ 4147 ] {ebe20568-9625-468c-8842-7ae78a90ae2a} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37854) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.dim_model update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:03.534325 [ 4147 ] {ebe20568-9625-468c-8842-7ae78a90ae2a} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:03.854358 [ 3084 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:04.026349 [ 3088 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:04.142346 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:04.152371 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:04.163364 [ 6609 ] {660cf23a-b65d-46bd-b085-d19968e3a212} executeQuery: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT kurtPop([], []);) 2025.10.23 23:31:04.178982 [ 6609 ] {660cf23a-b65d-46bd-b085-d19968e3a212} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:04.276433 [ 3091 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:04.398629 [ 6609 ] {5b21e6f1-98a2-4dd9-b43d-2bba992accf8} executeQuery: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT kurtSamp([], []);) 2025.10.23 23:31:04.418455 [ 6609 ] {5b21e6f1-98a2-4dd9-b43d-2bba992accf8} TCPHandler: Code: 42. DB::Exception: Aggregate function kurtSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:04.581022 [ 6609 ] {9d546679-7d9e-403f-95b5-c55fa45abd3a} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lagInFrame([], []);) 2025.10.23 23:31:04.601126 [ 6609 ] {9d546679-7d9e-403f-95b5-c55fa45abd3a} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) 2025.10.23 23:31:04.642094 [ 4147 ] {253738e5-aca4-4c11-b9bb-485728328ff7} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:9fb9179d-b496-4c23-9e47-1752876195df', current host ID: '793cd66ee8bf:9000:8324dd27-1907-4682-b0ec-85239088b116'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59018) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_2 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:04.647360 [ 4147 ] {253738e5-aca4-4c11-b9bb-485728328ff7} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:9fb9179d-b496-4c23-9e47-1752876195df', current host ID: '793cd66ee8bf:9000:8324dd27-1907-4682-b0ec-85239088b116'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:04.840682 [ 6609 ] {e21dd74b-6514-47ba-a1f0-8ef629fc5f92} executeQuery: Code: 48. DB::Exception: Aggregate function largestTriangleThreeBuckets only supports Date, Date32, DateTime, DateTime64 and Number as the first argument. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT largestTriangleThreeBuckets([], []);) 2025.10.23 23:31:04.856308 [ 3092 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:04.864173 [ 6609 ] {e21dd74b-6514-47ba-a1f0-8ef629fc5f92} TCPHandler: Code: 48. DB::Exception: Aggregate function largestTriangleThreeBuckets only supports Date, Date32, DateTime, DateTime64 and Number as the first argument. (NOT_IMPLEMENTED) 2025.10.23 23:31:04.944849 [ 4147 ] {16935d06-4c6e-419e-8546-750db2aa36a5} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59028) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:04.950825 [ 4147 ] {16935d06-4c6e-419e-8546-750db2aa36a5} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.014090 [ 6609 ] {207067ed-3ac8-4f8d-bfaf-8d4ff3a07555} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT last_value([], []);) 2025.10.23 23:31:05.040432 [ 6609 ] {207067ed-3ac8-4f8d-bfaf-8d4ff3a07555} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:05.107486 [ 3097 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:05.164580 [ 6609 ] {f5b33cdc-798d-4908-9c3a-7a76d721ca1c} executeQuery: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT last_value_respect_nulls([], []);) 2025.10.23 23:31:05.170510 [ 6609 ] {f5b33cdc-798d-4908-9c3a-7a76d721ca1c} TCPHandler: Code: 42. DB::Exception: Aggregate function anyLast_respect_nulls requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:05.200155 [ 6610 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.208115 [ 4415 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.282333 [ 3100 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:05.317503 [ 6609 ] {88d0884d-f8e5-4638-be5d-4b0864c8c9c9} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lcase([], []);) 2025.10.23 23:31:05.329358 [ 6609 ] {88d0884d-f8e5-4638-be5d-4b0864c8c9c9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lcase([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:05.455240 [ 6609 ] {0f933558-e724-48cc-af89-4bfc365a426e} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function lcm: In scope SELECT lcm([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lcm([], []);) 2025.10.23 23:31:05.458372 [ 6609 ] {0f933558-e724-48cc-af89-4bfc365a426e} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function lcm: In scope SELECT lcm([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:05.553835 [ 6609 ] {a98b7989-d455-4dd3-9bea-e07229179c75} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT leadInFrame([], []);) 2025.10.23 23:31:05.554945 [ 3677 ] {37b36a17-4eda-4d3c-8967-491e1b0da377} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59068) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.distributed_table_1 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.560986 [ 6609 ] {a98b7989-d455-4dd3-9bea-e07229179c75} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) 2025.10.23 23:31:05.566476 [ 3677 ] {37b36a17-4eda-4d3c-8967-491e1b0da377} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.620688 [ 4419 ] {8c8bf6d2-73ab-4c0f-bdf0-127a5caf19ca} executeQuery: Code: 81. DB::Exception: Database test_1_repl_01111_9 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59082) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1_repl_01111_9.rmt_26277_27210_27701 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1530: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291bbcd3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.634450 [ 4419 ] {8c8bf6d2-73ab-4c0f-bdf0-127a5caf19ca} TCPHandler: Code: 81. DB::Exception: Database test_1_repl_01111_9 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1530: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291bbcd3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.695159 [ 6610 ] {d0bf4ad3-0441-44d6-bc6c-e4ccb8e89a3b} executeQuery: Code: 999. Coordination::Exception: Can't get data for node '/test/01111/01111_create_drop_replicated_db_stress_test_1/max_log_ptr': node doesn't exist. (KEEPER_EXCEPTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59070) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_13 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000002e5f3bf1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000002e60df8c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x0000000027d52b4b 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4be44 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 8. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 9. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.727113 [ 6610 ] {d0bf4ad3-0441-44d6-bc6c-e4ccb8e89a3b} TCPHandler: Code: 999. Coordination::Exception: Can't get data for node '/test/01111/01111_create_drop_replicated_db_stress_test_1/max_log_ptr': node doesn't exist. (KEEPER_EXCEPTION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: Coordination::Exception::Exception(Coordination::Error, FormatStringHelperImpl::type>, String const&) @ 0x000000002e5f3bf1 4. ./build_docker/./src/Common/ZooKeeper/ZooKeeper.cpp:641: zkutil::ZooKeeper::get(String const&, Coordination::Stat*, std::shared_ptr const&) @ 0x000000002e60df8c 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::createReplicaNodesInZooKeeper(std::shared_ptr const&) @ 0x0000000027d52b4b 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4be44 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 8. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 9. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:31:05.858422 [ 3112 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:05.867773 [ 6609 ] {a37befdf-fa1b-4feb-b9e9-a7f66097a2e2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function left: In scope SELECT left([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT left([], []);) 2025.10.23 23:31:05.870444 [ 6609 ] {a37befdf-fa1b-4feb-b9e9-a7f66097a2e2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function left: In scope SELECT left([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:06.022093 [ 6609 ] {619cc7d7-f913-4f16-9bed-5ace6df89ec3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPad, should be string: In scope SELECT leftPad([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT leftPad([], []);) 2025.10.23 23:31:06.055311 [ 6609 ] {619cc7d7-f913-4f16-9bed-5ace6df89ec3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPad, should be string: In scope SELECT leftPad([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:06.109803 [ 3114 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:06.248306 [ 6609 ] {a274c462-f0a3-48a6-8243-066ebba90d96} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPadUTF8, should be string: In scope SELECT leftPadUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT leftPadUTF8([], []);) 2025.10.23 23:31:06.250087 [ 4419 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:06.250347 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:06.266142 [ 6609 ] {a274c462-f0a3-48a6-8243-066ebba90d96} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPadUTF8, should be string: In scope SELECT leftPadUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:06.287144 [ 3118 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:06.450816 [ 3385 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_91_101_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:06.472560 [ 6609 ] {6c7a1ead-a27f-492b-a97e-ff16d69fe485} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function leftUTF8: In scope SELECT leftUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT leftUTF8([], []);) 2025.10.23 23:31:06.480658 [ 6609 ] {6c7a1ead-a27f-492b-a97e-ff16d69fe485} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function leftUTF8: In scope SELECT leftUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:06.665333 [ 6609 ] {aa6d37cf-47bd-44dd-b46f-2f0176a1ea9c} executeQuery: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lemmatize([], []);) 2025.10.23 23:31:06.670586 [ 6609 ] {aa6d37cf-47bd-44dd-b46f-2f0176a1ea9c} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'lemmatize' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:31:06.742763 [ 6609 ] {22bdc93a-d733-4cf2-ad5c-20096ec13540} executeQuery: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT length([], []);) 2025.10.23 23:31:06.764083 [ 6609 ] {22bdc93a-d733-4cf2-ad5c-20096ec13540} TCPHandler: Code: 42. DB::Exception: Number of arguments for function length doesn't match: passed 2, should be 1: In scope SELECT length([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:06.860526 [ 3134 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:06.863510 [ 3527 ] {} void DB::AsyncLoader::worker(Pool &): Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286aac1d 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x000000002867c880 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: void std::__function::__policy_invoker const&)>::__call_impl, std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000027d93a03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b227edb 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:06.902134 [ 6609 ] {274cd529-03c1-4ded-a3f3-d03674ed1ee6} executeQuery: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lengthUTF8([], []);) 2025.10.23 23:31:06.917511 [ 6609 ] {274cd529-03c1-4ded-a3f3-d03674ed1ee6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lengthUTF8 doesn't match: passed 2, should be 1: In scope SELECT lengthUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:06.964421 [ 9676 ] {} DDLWorker(test_1_repl_01111_2): Error on initialization of test_1_repl_01111_2: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_1_repl_01111_2' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286aac1d 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x000000002867c880 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: void std::__function::__policy_invoker const&)>::__call_impl, std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000027d93a03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b227edb 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000001b221f93 5. ./src/Common/AsyncLoader.h:547: DB::DatabaseReplicated::waitDatabaseStarted() const @ 0x0000000027d58c96 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1054: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d6c76d 7. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 8. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:07.112064 [ 3137 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:07.203202 [ 6609 ] {1361b5a4-d430-445f-92e6-7dcb3d7eb0e9} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=720). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT less([], []);) 2025.10.23 23:31:07.230613 [ 6609 ] {1361b5a4-d430-445f-92e6-7dcb3d7eb0e9} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=720). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:31:07.294756 [ 3138 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:07.320796 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:07.356081 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:07.423527 [ 4415 ] {5e661703-e808-49dd-b31d-669be6fab5a5} executeQuery: Code: 48. DB::Exception: Table engine View doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59170) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.TestTbl_view update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:07.450413 [ 4415 ] {5e661703-e808-49dd-b31d-669be6fab5a5} TCPHandler: Code: 48. DB::Exception: Table engine View doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:07.537111 [ 8267 ] {c0f12701-7247-4c44-8f98-f63f7a55bc5d} executeQuery: Code: 81. DB::Exception: Database test_1_repl_01111_2 does not exist. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59198) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1_repl_01111_2.rmt_16371_14246_7151 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1530: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291bbcd3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:07.559983 [ 8267 ] {c0f12701-7247-4c44-8f98-f63f7a55bc5d} TCPHandler: Code: 81. DB::Exception: Database test_1_repl_01111_2 does not exist. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1530: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291bbcd3 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:07.654566 [ 6609 ] {dee6cb3f-ff0e-4b27-bc15-6c23e6a9734a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function editDistance: In scope SELECT levenshteinDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT levenshteinDistance([], []);) 2025.10.23 23:31:07.662083 [ 6609 ] {dee6cb3f-ff0e-4b27-bc15-6c23e6a9734a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function editDistance: In scope SELECT levenshteinDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:07.813642 [ 6609 ] {4b22de80-365e-4c9a-b3f2-e11d4e593e10} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function editDistanceUTF8: In scope SELECT levenshteinDistanceUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT levenshteinDistanceUTF8([], []);) 2025.10.23 23:31:07.826183 [ 6609 ] {4b22de80-365e-4c9a-b3f2-e11d4e593e10} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function editDistanceUTF8: In scope SELECT levenshteinDistanceUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:07.867079 [ 3149 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:07.940228 [ 6609 ] {a54eb322-7263-4a26-954f-ad798ed5ddd9} executeQuery: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lgamma([], []);) 2025.10.23 23:31:07.971462 [ 6609 ] {a54eb322-7263-4a26-954f-ad798ed5ddd9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lgamma doesn't match: passed 2, should be 1: In scope SELECT lgamma([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:08.059761 [ 6609 ] {adb07eab-2a7d-4f6d-8069-a7b77af37a60} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function like: In scope SELECT [] LIKE []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT like([], []);) 2025.10.23 23:31:08.071450 [ 6609 ] {adb07eab-2a7d-4f6d-8069-a7b77af37a60} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function like: In scope SELECT [] LIKE []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:08.114171 [ 3158 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:08.250958 [ 6609 ] {b7626ff1-4e5c-4115-a533-227d10641e32} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ln([], []);) 2025.10.23 23:31:08.278006 [ 6609 ] {b7626ff1-4e5c-4115-a533-227d10641e32} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT ln([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:08.297039 [ 3160 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:08.344169 [ 4419 ] {0563ef2c-4cd0-4f63-9b04-434e5b9d6a86} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59260) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:08.360936 [ 4419 ] {0563ef2c-4cd0-4f63-9b04-434e5b9d6a86} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:08.388449 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:08.417645 [ 6609 ] {c26b4903-8e43-4343-9452-2fb0d7307542} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function locate: In scope SELECT locate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT locate([], []);) 2025.10.23 23:31:08.419590 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:08.429418 [ 6609 ] {c26b4903-8e43-4343-9452-2fb0d7307542} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function locate: In scope SELECT locate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:08.585720 [ 6609 ] {8024623c-1be6-48c4-a689-56136474548c} executeQuery: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT log([], []);) 2025.10.23 23:31:08.600060 [ 6609 ] {8024623c-1be6-48c4-a689-56136474548c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log doesn't match: passed 2, should be 1: In scope SELECT log([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:08.711169 [ 6609 ] {c0dc9879-b460-46c2-a76b-2af100940264} executeQuery: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT log10([], []);) 2025.10.23 23:31:08.719567 [ 6609 ] {c0dc9879-b460-46c2-a76b-2af100940264} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log10 doesn't match: passed 2, should be 1: In scope SELECT log10([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:08.833255 [ 6609 ] {0e91f1ac-6ae1-4dd4-921c-a2a966a5d176} executeQuery: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT log1p([], []);) 2025.10.23 23:31:08.843642 [ 6609 ] {0e91f1ac-6ae1-4dd4-921c-a2a966a5d176} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log1p doesn't match: passed 2, should be 1: In scope SELECT log1p([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:08.868797 [ 3177 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:08.982192 [ 6609 ] {74d28098-581d-4358-a23e-6d5cf956225a} executeQuery: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT log2([], []);) 2025.10.23 23:31:08.989534 [ 6609 ] {74d28098-581d-4358-a23e-6d5cf956225a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function log2 doesn't match: passed 2, should be 1: In scope SELECT log2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:09.105223 [ 4419 ] {ee0441b0-af0f-43fb-a858-2124b87a5d42} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59288) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.elements update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:09.116646 [ 4419 ] {ee0441b0-af0f-43fb-a858-2124b87a5d42} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:09.118833 [ 3173 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:09.168646 [ 6609 ] {fa570242-f02e-478c-92f0-e2fbd6062f47} executeQuery: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT logTrace([], []);) 2025.10.23 23:31:09.183450 [ 6609 ] {fa570242-f02e-478c-92f0-e2fbd6062f47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function logTrace doesn't match: passed 2, should be 1: In scope SELECT logTrace([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:09.299014 [ 3184 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:09.344718 [ 6609 ] {a3fa54c8-f71e-4f47-89a4-c516526cef56} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lowCardinalityIndices([], []);) 2025.10.23 23:31:09.355277 [ 6609 ] {a3fa54c8-f71e-4f47-89a4-c516526cef56} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityIndices doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityIndices([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:09.401347 [ 3677 ] {b79147f3-08fb-44ea-a030-f850f897d5d0} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59320) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_3899_15480_32044 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:09.422307 [ 3677 ] {b79147f3-08fb-44ea-a030-f850f897d5d0} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:09.435533 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:09.459433 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:09.466066 [ 6609 ] {edb2e5b9-e391-44cd-8110-dcf068deb000} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lowCardinalityKeys([], []);) 2025.10.23 23:31:09.592323 [ 6609 ] {edb2e5b9-e391-44cd-8110-dcf068deb000} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowCardinalityKeys doesn't match: passed 2, should be 1: In scope SELECT lowCardinalityKeys([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:09.698950 [ 6609 ] {a041db85-bda0-45a0-8d41-5d153dc313ac} executeQuery: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lower([], []);) 2025.10.23 23:31:09.710044 [ 6609 ] {a041db85-bda0-45a0-8d41-5d153dc313ac} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lower doesn't match: passed 2, should be 1: In scope SELECT lower([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:09.818235 [ 6609 ] {36a5ce24-a7b7-4ede-a2bd-8e6339b5117e} executeQuery: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lowerUTF8([], []);) 2025.10.23 23:31:09.826588 [ 6609 ] {36a5ce24-a7b7-4ede-a2bd-8e6339b5117e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function lowerUTF8 doesn't match: passed 2, should be 1: In scope SELECT lowerUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:09.871294 [ 3166 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:09.967151 [ 6609 ] {3728b2df-e298-4e7d-bb01-de0eb600a4f5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPad, should be string: In scope SELECT lpad([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lpad([], []);) 2025.10.23 23:31:09.976279 [ 6609 ] {3728b2df-e298-4e7d-bb01-de0eb600a4f5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function leftPad, should be string: In scope SELECT lpad([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:10.077134 [ 6609 ] {b1e5eb7d-0c40-4583-9d7b-93b054cb1a88} executeQuery: Code: 48. DB::Exception: Aggregate function largestTriangleThreeBuckets only supports Date, Date32, DateTime, DateTime64 and Number as the first argument. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT lttb([], []);) 2025.10.23 23:31:10.091477 [ 6609 ] {b1e5eb7d-0c40-4583-9d7b-93b054cb1a88} TCPHandler: Code: 48. DB::Exception: Aggregate function largestTriangleThreeBuckets only supports Date, Date32, DateTime, DateTime64 and Number as the first argument. (NOT_IMPLEMENTED) 2025.10.23 23:31:10.120848 [ 3195 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:10.281882 [ 6609 ] {56c11940-8f7a-42a4-a66f-076fcf33c889} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Array(Nothing): In scope SELECT makeDate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT makeDate([], []);) 2025.10.23 23:31:10.300135 [ 6609 ] {56c11940-8f7a-42a4-a66f-076fcf33c889} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate'. Expected: Number, got: Array(Nothing): In scope SELECT makeDate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:10.301121 [ 3196 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:10.426818 [ 6609 ] {ce1f03e1-e849-45a6-bfa3-216bb22adf4f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Array(Nothing): In scope SELECT makeDate32([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT makeDate32([], []);) 2025.10.23 23:31:10.503869 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:10.541127 [ 6609 ] {ce1f03e1-e849-45a6-bfa3-216bb22adf4f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'year' to function 'makeDate32'. Expected: Number, got: Array(Nothing): In scope SELECT makeDate32([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:10.547433 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:10.647513 [ 6609 ] {3b50ece5-9c46-486d-beec-b22b5dfa5086} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT makeDateTime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT makeDateTime([], []);) 2025.10.23 23:31:10.658240 [ 6609 ] {3b50ece5-9c46-486d-beec-b22b5dfa5086} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime'. Expected 6 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT makeDateTime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:10.783211 [ 3677 ] {8bf8b86a-12bb-4e2e-9518-3170eb73032d} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59412) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.google_wrappers_02266 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:10.798511 [ 3677 ] {8bf8b86a-12bb-4e2e-9518-3170eb73032d} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:10.818390 [ 6609 ] {55800d4a-e119-42a5-ac52-f2c9d6a13ab8} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 2 arguments: In scope SELECT makeDateTime64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT makeDateTime64([], []);) 2025.10.23 23:31:10.835833 [ 6609 ] {55800d4a-e119-42a5-ac52-f2c9d6a13ab8} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'makeDateTime64'. Expected 6 mandatory arguments and 3 optional arguments, got 2 arguments: In scope SELECT makeDateTime64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:10.873212 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:10.895053 [ 6609 ] {2a0bf186-230b-4dd2-ad13-f00bc7393501} executeQuery: Code: 48. DB::Exception: Aggregate function mannWhitneyUTest only supports numerical types. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mannWhitneyUTest([], []);) 2025.10.23 23:31:10.915791 [ 6609 ] {2a0bf186-230b-4dd2-ad13-f00bc7393501} TCPHandler: Code: 48. DB::Exception: Aggregate function mannWhitneyUTest only supports numerical types. (NOT_IMPLEMENTED) 2025.10.23 23:31:10.983531 [ 4419 ] {b9531d09-31da-46fd-868a-7a4e9b1e2d7e} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59424) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1.rmt_1130_8622_7545 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:11.007280 [ 4419 ] {b9531d09-31da-46fd-868a-7a4e9b1e2d7e} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:11.123799 [ 3209 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:11.246485 [ 6609 ] {b5f9ddbe-247e-485f-a654-e31bd0a0a03a} executeQuery: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapAdd([], []);) 2025.10.23 23:31:11.275696 [ 6609 ] {b5f9ddbe-247e-485f-a654-e31bd0a0a03a} TCPHandler: Code: 43. DB::Exception: mapAdd only accepts maps: In scope SELECT mapAdd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:11.304326 [ 3210 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:11.431043 [ 6609 ] {886915a3-eef9-476f-b826-5d4088e852a9} executeQuery: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapAll([], []);) 2025.10.23 23:31:11.452850 [ 6609 ] {886915a3-eef9-476f-b826-5d4088e852a9} TCPHandler: Code: 43. DB::Exception: Function mapAll requires at least one argument of type Map: In scope SELECT mapAll([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:11.650627 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:11.651041 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:11.653455 [ 6609 ] {60042fd1-f53c-4e57-b112-93b35f5f27c2} executeQuery: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapApply([], []);) 2025.10.23 23:31:11.679309 [ 6609 ] {60042fd1-f53c-4e57-b112-93b35f5f27c2} TCPHandler: Code: 43. DB::Exception: Function mapApply requires at least one argument of type Map: In scope SELECT mapApply([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:11.874892 [ 3217 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:11.875347 [ 6609 ] {9f3d6ff3-98c0-4fd2-9e39-b19e5284688c} executeQuery: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapConcat([], []);) 2025.10.23 23:31:11.895348 [ 6609 ] {9f3d6ff3-98c0-4fd2-9e39-b19e5284688c} TCPHandler: Code: 43. DB::Exception: Function mapConcat requires at least one argument of type Map: In scope SELECT mapConcat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:12.014341 [ 6610 ] {9ea06f12-c653-45f3-a789-6f8d77823863} executeQuery: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_1_repl_01111_2' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286aac1d 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x000000002867c880 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: void std::__function::__policy_invoker const&)>::__call_impl, std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000027d93a03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b227edb 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59120) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_2 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000001b221f93 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000001b1acebc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919adf5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:12.027665 [ 6610 ] {9ea06f12-c653-45f3-a789-6f8d77823863} TCPHandler: Code: 722. DB::Exception: Waited job failed: Code: 695. DB::Exception: Load job 'startup Replicated database test_1_repl_01111_2' failed: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=721). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286aac1d 7. ./build_docker/./src/Interpreters/DDLWorker.cpp:132: DB::DDLWorker::startup() @ 0x000000002867c880 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: void std::__function::__policy_invoker const&)>::__call_impl, std::hash>, std::equal_to>, std::allocator>>, DB::LoadingStrictnessLevel)::$_0, void (DB::AsyncLoader&, std::shared_ptr const&)>>(std::__function::__policy_storage const*, DB::AsyncLoader&, std::shared_ptr const&) @ 0x0000000027d93a03 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001b227edb 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 11. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_FAILED) (version 24.8.14.10542.altinitytest (altinity build)). (ASYNC_LOAD_WAIT_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Common/AsyncLoader.cpp:444: DB::AsyncLoader::wait(std::shared_ptr const&, bool) @ 0x000000001b221f93 5. ./src/Common/AsyncLoader.h:547: DB::waitLoad(unsigned long, std::vector, std::allocator>> const&, bool) @ 0x000000001b1acebc 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919adf5 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:12.077666 [ 6609 ] {54cd911d-7116-40c3-a753-6b8f4252e353} executeQuery: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapContains([], []);) 2025.10.23 23:31:12.084422 [ 6609 ] {54cd911d-7116-40c3-a753-6b8f4252e353} TCPHandler: Code: 43. DB::Exception: Function mapContains requires at least one argument of type Map: In scope SELECT mapContains([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:12.137350 [ 3224 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:12.229485 [ 6609 ] {95543759-4495-411c-b464-310e82e32ac0} executeQuery: Code: 43. DB::Exception: First argument for function mapContainsKeyLike must be a Map: In scope SELECT mapContainsKeyLike([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapContainsKeyLike([], []);) 2025.10.23 23:31:12.238587 [ 6609 ] {95543759-4495-411c-b464-310e82e32ac0} TCPHandler: Code: 43. DB::Exception: First argument for function mapContainsKeyLike must be a Map: In scope SELECT mapContainsKeyLike([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:12.306444 [ 3228 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:12.512276 [ 6609 ] {fd40b140-48af-4165-8c5d-01b3b7849174} executeQuery: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapExists([], []);) 2025.10.23 23:31:12.532342 [ 6609 ] {fd40b140-48af-4165-8c5d-01b3b7849174} TCPHandler: Code: 43. DB::Exception: Function mapExists requires at least one argument of type Map: In scope SELECT mapExists([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:12.651609 [ 6609 ] {a0251e64-0048-478b-9b90-b288e55e8b7f} executeQuery: Code: 43. DB::Exception: First argument for function mapExtractKeyLike must be a Map: In scope SELECT mapExtractKeyLike([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapExtractKeyLike([], []);) 2025.10.23 23:31:12.664867 [ 6609 ] {a0251e64-0048-478b-9b90-b288e55e8b7f} TCPHandler: Code: 43. DB::Exception: First argument for function mapExtractKeyLike must be a Map: In scope SELECT mapExtractKeyLike([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:12.720492 [ 4419 ] {8455fcac-969b-48fc-8e82-0ad1fa669735} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59504) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.pl update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:12.722753 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:12.732006 [ 4419 ] {8455fcac-969b-48fc-8e82-0ad1fa669735} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:12.784243 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:12.792138 [ 6609 ] {d4178cf2-87b0-4e55-b208-7c565472177a} executeQuery: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapFilter([], []);) 2025.10.23 23:31:12.864404 [ 6609 ] {d4178cf2-87b0-4e55-b208-7c565472177a} TCPHandler: Code: 43. DB::Exception: Function mapFilter requires at least one argument of type Map: In scope SELECT mapFilter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:12.868843 [ 4049 ] {ac270fd3-4546-4e95-a270-dec16c583f56} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59518) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1.rmt_13028_16835_17248 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:12.877102 [ 3248 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:12.887638 [ 4049 ] {ac270fd3-4546-4e95-a270-dec16c583f56} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:12.969727 [ 9636 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:31:18: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:13.114026 [ 6609 ] {8af8b04c-c43c-4a9f-ae27-2b021d8d1539} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT mapFromString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapFromString([], []);) 2025.10.23 23:31:13.127685 [ 6609 ] {8af8b04c-c43c-4a9f-ae27-2b021d8d1539} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT mapFromString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:13.169219 [ 3241 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:13.256530 [ 6609 ] {70b537bf-51cf-47f0-bd62-c8e41620c228} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapKeys([], []);) 2025.10.23 23:31:13.263182 [ 6609 ] {70b537bf-51cf-47f0-bd62-c8e41620c228} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapKeys doesn't match: passed 2, should be 1: In scope SELECT mapKeys([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:13.309180 [ 3247 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:13.469750 [ 6609 ] {cf11d0e1-3613-4912-8f15-ec79fb3b6802} executeQuery: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapPartialReverseSort([], []);) 2025.10.23 23:31:13.494365 [ 6609 ] {cf11d0e1-3613-4912-8f15-ec79fb3b6802} TCPHandler: Code: 43. DB::Exception: Function mapPartialReverseSort requires at least one argument of type Map: In scope SELECT mapPartialReverseSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:13.649101 [ 6609 ] {08d6d1b6-2ed5-4e98-a0c9-b7d9d55446fe} executeQuery: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapPartialSort([], []);) 2025.10.23 23:31:13.660002 [ 6609 ] {08d6d1b6-2ed5-4e98-a0c9-b7d9d55446fe} TCPHandler: Code: 43. DB::Exception: Function mapPartialSort requires at least one argument of type Map: In scope SELECT mapPartialSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:13.760061 [ 6609 ] {fe165103-504d-44a8-8368-1084eb85963a} executeQuery: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type Nothing: In scope SELECT mapPopulateSeries([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapPopulateSeries([], []);) 2025.10.23 23:31:13.764916 [ 6609 ] {fe165103-504d-44a8-8368-1084eb85963a} TCPHandler: Code: 43. DB::Exception: Function mapPopulateSeries key argument should be of signed or unsigned integer type. Actual type Nothing: In scope SELECT mapPopulateSeries([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:13.781360 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:13.832207 [ 4049 ] {6a688e55-648e-426e-a5f4-16226c5572ab} executeQuery: Code: 36. DB::Exception: Object in bucket test with key test_02245 already exists. If you want to overwrite it, enable setting s3_truncate_on_insert, if you want to create a new file on each insert, enable setting s3_create_new_file_on_insert. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59564) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: insert into test_1.test_02245 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&, String&&) @ 0x0000000026822de6 4. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:38: DB::checkAndGetNewFileOnInsertIfNeeded(DB::IObjectStorage const&, DB::StorageObjectStorage::Configuration const&, DB::StorageObjectStorage::QuerySettings const&, String const&, unsigned long) @ 0x0000000026821516 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000267be474 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293667b0 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:794: DB::InterpreterInsertQuery::execute() @ 0x0000000029369e59 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:31:13.855274 [ 4049 ] {6a688e55-648e-426e-a5f4-16226c5572ab} TCPHandler: Code: 36. DB::Exception: Object in bucket test with key test_02245 already exists. If you want to overwrite it, enable setting s3_truncate_on_insert, if you want to create a new file on each insert, enable setting s3_create_new_file_on_insert. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&, String&&) @ 0x0000000026822de6 4. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:38: DB::checkAndGetNewFileOnInsertIfNeeded(DB::IObjectStorage const&, DB::StorageObjectStorage::Configuration const&, DB::StorageObjectStorage::QuerySettings const&, String const&, unsigned long) @ 0x0000000026821516 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000267be474 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293667b0 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:794: DB::InterpreterInsertQuery::execute() @ 0x0000000029369e59 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:31:13.882561 [ 3253 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:13.886900 [ 6609 ] {86c49364-0f85-48af-9e06-5b56f9113143} executeQuery: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapReverseSort([], []);) 2025.10.23 23:31:13.914566 [ 6609 ] {86c49364-0f85-48af-9e06-5b56f9113143} TCPHandler: Code: 43. DB::Exception: Function mapReverseSort requires at least one argument of type Map: In scope SELECT mapReverseSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:13.919994 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:13.987746 [ 4203 ] {f851e54b-ef16-4ed4-8e05-ba3b9e3b6e57} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59604) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:14.005026 [ 4203 ] {f851e54b-ef16-4ed4-8e05-ba3b9e3b6e57} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:14.026078 [ 6609 ] {5a6b8941-65ca-45ba-a21d-bfac72a1673c} executeQuery: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapSort([], []);) 2025.10.23 23:31:14.067278 [ 6609 ] {5a6b8941-65ca-45ba-a21d-bfac72a1673c} TCPHandler: Code: 43. DB::Exception: Function mapSort requires at least one argument of type Map: In scope SELECT mapSort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:14.171365 [ 3261 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:14.256487 [ 6609 ] {86d98546-2bf2-43c1-8d73-b3fe0aa4d036} executeQuery: Code: 43. DB::Exception: mapSubtract only accepts maps: In scope SELECT mapSubtract([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapSubtract([], []);) 2025.10.23 23:31:14.301845 [ 6609 ] {86d98546-2bf2-43c1-8d73-b3fe0aa4d036} TCPHandler: Code: 43. DB::Exception: mapSubtract only accepts maps: In scope SELECT mapSubtract([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:14.312375 [ 3267 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:14.377871 [ 6609 ] {cd151229-c9e2-4c34-bd36-1e21389f3537} executeQuery: Code: 43. DB::Exception: The two arguments for function mapUpdate must be both Map type: In scope SELECT mapUpdate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapUpdate([], []);) 2025.10.23 23:31:14.392680 [ 6609 ] {cd151229-c9e2-4c34-bd36-1e21389f3537} TCPHandler: Code: 43. DB::Exception: The two arguments for function mapUpdate must be both Map type: In scope SELECT mapUpdate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:14.525313 [ 6609 ] {c6a0bc0a-9064-47ad-ba89-1371f6ee07c4} executeQuery: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mapValues([], []);) 2025.10.23 23:31:14.541486 [ 6609 ] {c6a0bc0a-9064-47ad-ba89-1371f6ee07c4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function mapValues doesn't match: passed 2, should be 1: In scope SELECT mapValues([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:14.747890 [ 6609 ] {21e3d054-866d-4e99-8586-2faebc10ca5d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function match: In scope SELECT match([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT match([], []);) 2025.10.23 23:31:14.760049 [ 6609 ] {21e3d054-866d-4e99-8586-2faebc10ca5d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function match: In scope SELECT match([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:14.847116 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:14.886322 [ 3283 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:14.886394 [ 6609 ] {aee81585-fc10-494a-a715-6b73ed638352} executeQuery: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT materialize([], []);) 2025.10.23 23:31:14.898665 [ 6609 ] {aee81585-fc10-494a-a715-6b73ed638352} TCPHandler: Code: 42. DB::Exception: Number of arguments for function materialize doesn't match: passed 2, should be 1: In scope SELECT materialize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:14.968073 [ 4203 ] {d291ac33-72e3-4d17-a162-777a83de18be} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45858) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.test_index update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:15.028880 [ 4203 ] {d291ac33-72e3-4d17-a162-777a83de18be} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:15.039944 [ 6609 ] {96764880-a274-4679-b62c-72ccb373e558} executeQuery: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT max([], []);) 2025.10.23 23:31:15.043037 [ 6609 ] {96764880-a274-4679-b62c-72ccb373e558} TCPHandler: Code: 42. DB::Exception: Aggregate function max requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:15.071475 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:15.142770 [ 6609 ] {d8c33531-1983-42dd-9099-dc0714a15984} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function max2: In scope SELECT max2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT max2([], []);) 2025.10.23 23:31:15.172601 [ 6609 ] {d8c33531-1983-42dd-9099-dc0714a15984} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function max2: In scope SELECT max2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:15.175030 [ 3280 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:15.241709 [ 6609 ] {ae0455f5-6086-4916-b3ee-68e952fd0775} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of argument for aggregate function maxIntersections. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT maxIntersections([], []);) 2025.10.23 23:31:15.247466 [ 6609 ] {ae0455f5-6086-4916-b3ee-68e952fd0775} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of argument for aggregate function maxIntersections. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:15.314945 [ 2772 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:15.341000 [ 6609 ] {0bcc45b5-ccfd-4d1b-8170-6c44df9fd032} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of argument for aggregate function maxIntersectionsPosition. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT maxIntersectionsPosition([], []);) 2025.10.23 23:31:15.348392 [ 6609 ] {0bcc45b5-ccfd-4d1b-8170-6c44df9fd032} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of argument for aggregate function maxIntersectionsPosition. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:15.727310 [ 6609 ] {cdd1beb3-d44f-4fce-a2b9-8a91e7c56f8a} executeQuery: Code: 42. DB::Exception: Aggregate function meanZTest requires three parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT meanZTest([], []);) 2025.10.23 23:31:15.745534 [ 6609 ] {cdd1beb3-d44f-4fce-a2b9-8a91e7c56f8a} TCPHandler: Code: 42. DB::Exception: Aggregate function meanZTest requires three parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:15.819255 [ 3621 ] {023cde7a-4d88-4056-ad1e-e79fa327524a} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:15.826498 [ 3621 ] {023cde7a-4d88-4056-ad1e-e79fa327524a} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:15.855712 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (1 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:15.889375 [ 2805 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:15.901767 [ 6609 ] {0ab6390a-8bce-4cab-83e2-7fbe6d4f3784} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT median([], []);) 2025.10.23 23:31:15.922011 [ 6609 ] {0ab6390a-8bce-4cab-83e2-7fbe6d4f3784} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:15.936350 [ 4294 ] {26491626-4a91-4484-b28b-ba31b80fe644} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45914) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:15.956954 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:15.957016 [ 4294 ] {26491626-4a91-4484-b28b-ba31b80fe644} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:16.102748 [ 6609 ] {3da79cf2-763a-4460-b44a-9e18510dae4c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianBFloat16([], []);) 2025.10.23 23:31:16.105815 [ 3677 ] {1c48e77a-2f54-4994-b711-c08d132b3979} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:4eecbc6e-fd97-4e61-b687-172eedfa9bff'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45928) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_7 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:16.107124 [ 6609 ] {3da79cf2-763a-4460-b44a-9e18510dae4c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:16.111531 [ 3677 ] {1c48e77a-2f54-4994-b711-c08d132b3979} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:4eecbc6e-fd97-4e61-b687-172eedfa9bff'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:16.163297 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:16.181786 [ 2810 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:16.233990 [ 6609 ] {0d5e548e-8283-4deb-a3a6-5cea4fcd7a9a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianBFloat16Weighted([], []);) 2025.10.23 23:31:16.263954 [ 6609 ] {0d5e548e-8283-4deb-a3a6-5cea4fcd7a9a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:16.317204 [ 2808 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:16.436358 [ 6609 ] {ad3e2913-9bda-412a-af66-e92cc08796a4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianDD([], []);) 2025.10.23 23:31:16.458162 [ 6609 ] {ad3e2913-9bda-412a-af66-e92cc08796a4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:16.701271 [ 6609 ] {efa37592-e9fd-41b0-931c-19e6fd3ad922} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianDeterministic([], []);) 2025.10.23 23:31:16.722982 [ 6609 ] {efa37592-e9fd-41b0-931c-19e6fd3ad922} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:16.876114 [ 6609 ] {468cbcf6-faf0-44d9-a7e9-13a538012d2f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianExact([], []);) 2025.10.23 23:31:16.882751 [ 6609 ] {468cbcf6-faf0-44d9-a7e9-13a538012d2f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:16.891942 [ 2815 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:16.960347 [ 4049 ] {7e6a7f94-d87b-4864-898e-e7e21c94ac59} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45974) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.distributed_table_1 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:16.971720 [ 4049 ] {7e6a7f94-d87b-4864-898e-e7e21c94ac59} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:17.017384 [ 6609 ] {b14a5e69-7298-46b4-b3ee-bab255a3dded} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianExactHigh([], []);) 2025.10.23 23:31:17.022967 [ 6609 ] {b14a5e69-7298-46b4-b3ee-bab255a3dded} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:17.055074 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:17.158447 [ 6609 ] {ab7ff26f-f963-464e-81ea-fafed6a576af} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianExactLow([], []);) 2025.10.23 23:31:17.165264 [ 6609 ] {ab7ff26f-f963-464e-81ea-fafed6a576af} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:17.183802 [ 2820 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:17.206424 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:17.319349 [ 2831 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:17.330192 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:17.342485 [ 6609 ] {53d74dd2-1018-48b7-a591-f858f6d7af25} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianExactWeighted([], []);) 2025.10.23 23:31:17.350699 [ 6609 ] {53d74dd2-1018-48b7-a591-f858f6d7af25} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:17.469662 [ 6609 ] {ed957d66-2fae-470c-b031-04b044ea50b3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianGK([], []);) 2025.10.23 23:31:17.475500 [ 6609 ] {ed957d66-2fae-470c-b031-04b044ea50b3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:17.586153 [ 6609 ] {a5422772-786c-4e7b-8c9a-a26716458f88} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianInterpolatedWeighted([], []);) 2025.10.23 23:31:17.599108 [ 6609 ] {a5422772-786c-4e7b-8c9a-a26716458f88} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:17.646068 [ 4294 ] {c2888d9d-7b98-4a25-be14-9680cb583aa4} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46016) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:17.670497 [ 4294 ] {c2888d9d-7b98-4a25-be14-9680cb583aa4} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:17.671730 [ 3677 ] {755aa625-614b-45be-969a-d117491c5cc8} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46006) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_11.rmt_31580_17077_20186 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:17.710336 [ 3677 ] {755aa625-614b-45be-969a-d117491c5cc8} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:17.765058 [ 6609 ] {d9639f38-9a55-445f-82d1-f87524fdbf9e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianTDigest([], []);) 2025.10.23 23:31:17.806336 [ 6609 ] {d9639f38-9a55-445f-82d1-f87524fdbf9e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:17.894071 [ 2837 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:18.017241 [ 6609 ] {1b206bb6-71b2-48e1-80a5-45209490b096} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianTDigestWeighted([], []);) 2025.10.23 23:31:18.024688 [ 6609 ] {1b206bb6-71b2-48e1-80a5-45209490b096} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:18.123939 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:18.187080 [ 2840 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:18.219611 [ 3677 ] {2c602bfe-c9bd-4463-8df0-a6a8cafa40d4} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:b7b5d71c-e2f7-4d4a-b0df-dde306234300', current host ID: '793cd66ee8bf:9000:de7a0ad7-9ea9-4f71-b75d-302104a76331'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46046) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_9 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:18.230427 [ 3677 ] {2c602bfe-c9bd-4463-8df0-a6a8cafa40d4} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:b7b5d71c-e2f7-4d4a-b0df-dde306234300', current host ID: '793cd66ee8bf:9000:de7a0ad7-9ea9-4f71-b75d-302104a76331'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:18.267769 [ 6609 ] {8a2ec284-98c7-4928-890c-bdcb2e4a869a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianTiming([], []);) 2025.10.23 23:31:18.288182 [ 6609 ] {8a2ec284-98c7-4928-890c-bdcb2e4a869a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:18.329053 [ 2842 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:18.347065 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:18.484465 [ 6609 ] {37fa43bf-df66-4811-b365-857e24c3c439} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT medianTimingWeighted([], []);) 2025.10.23 23:31:18.492192 [ 6609 ] {37fa43bf-df66-4811-b365-857e24c3c439} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:18.662361 [ 4049 ] {aa18d6ea-fc78-4d29-804e-221bbbe89681} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46086) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.data update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:18.714328 [ 4049 ] {aa18d6ea-fc78-4d29-804e-221bbbe89681} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:18.896216 [ 2845 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:18.944901 [ 6609 ] {43275ef1-b790-4102-8a2f-b98322a67561} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT mid([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mid([], []);) 2025.10.23 23:31:18.981383 [ 6609 ] {43275ef1-b790-4102-8a2f-b98322a67561} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT mid([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:19.150351 [ 6609 ] {e9cffe0c-bde9-4e1e-b207-05ea5a3c3219} executeQuery: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT min([], []);) 2025.10.23 23:31:19.153215 [ 4294 ] {48e1661f-e08e-4e5a-8a7f-258323294faf} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:b030ebef-a318-4167-b36c-03c2e7a91bae'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46100) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_12 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:19.155638 [ 4294 ] {48e1661f-e08e-4e5a-8a7f-258323294faf} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:b030ebef-a318-4167-b36c-03c2e7a91bae'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:19.158318 [ 6609 ] {e9cffe0c-bde9-4e1e-b207-05ea5a3c3219} TCPHandler: Code: 42. DB::Exception: Aggregate function min requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:19.188891 [ 2857 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:19.274413 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:19.275110 [ 3677 ] {22f36db4-b4b9-43fe-9efd-5a6d62421aec} executeQuery: Code: 60. DB::Exception: Table default.local_table_1 does not exist. Maybe you meant test_11.local_table_1?. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46096) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: insert into test_11.distributed_table_1 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000002c22504a 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x000000002c217ffd 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000002c215a79 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbfe1ce 13. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9de3da 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9ddef1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9dd046 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d1a6573 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192b98 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:31:19.286779 [ 3677 ] {22f36db4-b4b9-43fe-9efd-5a6d62421aec} TCPHandler: Code: 60. DB::Exception: Table default.local_table_1 does not exist. Maybe you meant test_11.local_table_1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000002c22504a 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x000000002c217ffd 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000002c215a79 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbfe1ce 13. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9de3da 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9ddef1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9dd046 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d1a6573 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192b98 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:31:19.331369 [ 2853 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:19.340195 [ 6609 ] {a95d525a-c280-4908-a748-ba30cca13ae8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function min2: In scope SELECT min2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT min2([], []);) 2025.10.23 23:31:19.343519 [ 4203 ] {f39f4a4e-ce00-4a2b-b31e-1f51b7f0a7ad} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46106) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_17737_10569_9630 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:19.367268 [ 6609 ] {a95d525a-c280-4908-a748-ba30cca13ae8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function min2: In scope SELECT min2([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:19.382646 [ 4203 ] {f39f4a4e-ce00-4a2b-b31e-1f51b7f0a7ad} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:31:19.446727 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:19.735513 [ 6609 ] {f2617d61-d8b0-4bdd-8cda-c15887e6409d} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT minSampleSizeContinous([], []);) 2025.10.23 23:31:19.753505 [ 6609 ] {f2617d61-d8b0-4bdd-8cda-c15887e6409d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinous([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:19.898060 [ 2868 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:19.949213 [ 6609 ] {7107cae0-e7b2-4bd8-86f0-f51aa52c5978} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT minSampleSizeContinuous([], []);) 2025.10.23 23:31:19.971525 [ 6609 ] {7107cae0-e7b2-4bd8-86f0-f51aa52c5978} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeContinuous doesn't match: passed 2, should be 5: In scope SELECT minSampleSizeContinuous([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:20.131644 [ 6609 ] {6f9dc77d-cca6-470e-a0ed-4078dd6d1925} executeQuery: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT minSampleSizeConversion([], []);) 2025.10.23 23:31:20.150990 [ 6609 ] {6f9dc77d-cca6-470e-a0ed-4078dd6d1925} TCPHandler: Code: 42. DB::Exception: Number of arguments for function minSampleSizeConversion doesn't match: passed 2, should be 4: In scope SELECT minSampleSizeConversion([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:20.194587 [ 2875 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:20.342822 [ 2876 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:20.356029 [ 6609 ] {e0c6047b-1cb2-4db4-a073-d39dd095c4c2} executeQuery: Code: 43. DB::Exception: Illegal types Nothing and Nothing of arguments of function minus: In scope SELECT [] - []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT minus([], []);) 2025.10.23 23:31:20.358549 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:20.370653 [ 6609 ] {e0c6047b-1cb2-4db4-a073-d39dd095c4c2} TCPHandler: Code: 43. DB::Exception: Illegal types Nothing and Nothing of arguments of function minus: In scope SELECT [] - []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:20.426162 [ 4076 ] {d19290b6-b1c2-44dd-93cc-ea966df2f3b5} executeQuery: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_4: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46108) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1_repl_01111_4), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:20.441252 [ 4076 ] {d19290b6-b1c2-44dd-93cc-ea966df2f3b5} TCPHandler: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_4: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:20.517559 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:20.592088 [ 6609 ] {061dbf2f-bb7b-4c0c-b215-2c329ebfcc01} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function byteHammingDistance: In scope SELECT mismatches([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mismatches([], []);) 2025.10.23 23:31:20.612728 [ 6609 ] {061dbf2f-bb7b-4c0c-b215-2c329ebfcc01} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function byteHammingDistance: In scope SELECT mismatches([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:20.659039 [ 4049 ] {acb668a0-3bb5-42bb-8f65-c5e3676b2efd} executeQuery: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46172) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.local_01099_a update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:20.670502 [ 4049 ] {acb668a0-3bb5-42bb-8f65-c5e3676b2efd} TCPHandler: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:20.807224 [ 6609 ] {0f0fed8e-dba4-4cc8-ad2a-6b99a85292a6} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function modulo: In scope SELECT mod([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mod([], []);) 2025.10.23 23:31:20.819495 [ 6609 ] {0f0fed8e-dba4-4cc8-ad2a-6b99a85292a6} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function modulo: In scope SELECT mod([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:20.900084 [ 2884 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:21.029562 [ 6609 ] {af4fd57b-5dfd-4a63-8010-d445c0719492} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function modulo: In scope SELECT [] % []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT modulo([], []);) 2025.10.23 23:31:21.041094 [ 3621 ] {a5005025-668b-4273-854c-050ad3f74bc0} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:21.049316 [ 3621 ] {a5005025-668b-4273-854c-050ad3f74bc0} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:21.066780 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (2 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:21.083308 [ 4294 ] {5327284e-a113-445e-9a73-012e19491985} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:ebe16345-3b3e-401d-8696-760471d98c11', current host ID: '793cd66ee8bf:9000:b2268fd8-fc98-4f23-9a48-fe7e6c2a710e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46204) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_0 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:21.095041 [ 6609 ] {af4fd57b-5dfd-4a63-8010-d445c0719492} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function modulo: In scope SELECT [] % []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:21.118834 [ 4294 ] {5327284e-a113-445e-9a73-012e19491985} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:ebe16345-3b3e-401d-8696-760471d98c11', current host ID: '793cd66ee8bf:9000:b2268fd8-fc98-4f23-9a48-fe7e6c2a710e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:21.196808 [ 2894 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:21.243336 [ 6609 ] {e971ac01-8129-4a9d-bdd5-d9ed79217c95} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function moduloLegacy: In scope SELECT moduloLegacy([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT moduloLegacy([], []);) 2025.10.23 23:31:21.252738 [ 6609 ] {e971ac01-8129-4a9d-bdd5-d9ed79217c95} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function moduloLegacy: In scope SELECT moduloLegacy([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:21.345257 [ 2898 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:21.355665 [ 6609 ] {d4112635-268f-49fe-ba40-983256d7a57b} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function moduloOrZero: In scope SELECT moduloOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT moduloOrZero([], []);) 2025.10.23 23:31:21.369106 [ 6609 ] {d4112635-268f-49fe-ba40-983256d7a57b} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function moduloOrZero: In scope SELECT moduloOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:21.391063 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:21.522684 [ 6609 ] {2a7d90b2-433a-476e-9079-9cb5bc590011} executeQuery: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT monthName([], []);) 2025.10.23 23:31:21.543395 [ 6609 ] {2a7d90b2-433a-476e-9079-9cb5bc590011} TCPHandler: Code: 42. DB::Exception: Number of arguments for function monthName doesn't match: passed 2, should be 1: In scope SELECT monthName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:21.649023 [ 4203 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:21.854148 [ 6609 ] {c25d8bb7-5387-41e0-a58a-103d67377bca} executeQuery: Code: 44. DB::Exception: Illegal column type Array(Nothing) for function mortonDecode, should be a native UInt: In scope SELECT mortonDecode([], []). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mortonDecode([], []);) 2025.10.23 23:31:21.902000 [ 2902 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:22.051088 [ 6609 ] {c25d8bb7-5387-41e0-a58a-103d67377bca} TCPHandler: Code: 44. DB::Exception: Illegal column type Array(Nothing) for function mortonDecode, should be a native UInt: In scope SELECT mortonDecode([], []). (ILLEGAL_COLUMN) 2025.10.23 23:31:22.165669 [ 6609 ] {09efecef-8698-40d3-8079-76d87efd7349} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT mortonEncode([], []);) 2025.10.23 23:31:22.179980 [ 6609 ] {09efecef-8698-40d3-8079-76d87efd7349} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for function mortonEncode, should be a native UInt: In scope SELECT mortonEncode([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:22.198736 [ 2914 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:22.337854 [ 6609 ] {8cb61c4e-949b-49fd-9afe-7fb06c55f911} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiFuzzyMatchAllIndices([], []);) 2025.10.23 23:31:22.347393 [ 2915 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:22.348069 [ 6609 ] {8cb61c4e-949b-49fd-9afe-7fb06c55f911} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAllIndices doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAllIndices([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:22.407677 [ 3677 ] {90d1f753-0a8c-456f-9988-0e50e0503acb} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46278) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:22.415092 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:22.418454 [ 3677 ] {90d1f753-0a8c-456f-9988-0e50e0503acb} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:22.480499 [ 6609 ] {e8eb319b-60f1-4e2a-b609-c82b2b6381a5} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiFuzzyMatchAny([], []);) 2025.10.23 23:31:22.481971 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:22.486989 [ 6609 ] {e8eb319b-60f1-4e2a-b609-c82b2b6381a5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAny doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAny([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:22.712440 [ 4076 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:22.739545 [ 6609 ] {323ad3f1-e612-4a41-a7e1-3eda0a6d0e9a} executeQuery: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiFuzzyMatchAnyIndex([], []);) 2025.10.23 23:31:22.746525 [ 6609 ] {323ad3f1-e612-4a41-a7e1-3eda0a6d0e9a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function multiFuzzyMatchAnyIndex doesn't match: passed 2, should be 3: In scope SELECT multiFuzzyMatchAnyIndex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:22.749463 [ 3677 ] {4245d49f-17d8-4f78-b75b-ba63af609ba2} executeQuery: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46310) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.distributed_01099_b update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:22.758539 [ 3677 ] {4245d49f-17d8-4f78-b75b-ba63af609ba2} TCPHandler: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:31:22.885480 [ 6609 ] {454f693f-347b-4a68-a48f-cb17e412be7f} executeQuery: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiIf([], []);) 2025.10.23 23:31:22.901132 [ 6609 ] {454f693f-347b-4a68-a48f-cb17e412be7f} TCPHandler: Code: 42. DB::Exception: Invalid number of arguments for function multiIf: In scope SELECT multiIf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:22.955161 [ 2929 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:23.041964 [ 6609 ] {e1e3e3cc-dc7b-4d9e-98bf-2cf28b53921f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiMatchAllIndices: In scope SELECT multiMatchAllIndices([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiMatchAllIndices([], []);) 2025.10.23 23:31:23.054248 [ 6609 ] {e1e3e3cc-dc7b-4d9e-98bf-2cf28b53921f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiMatchAllIndices: In scope SELECT multiMatchAllIndices([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:23.208235 [ 2934 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:23.235531 [ 6609 ] {dc8d2a1b-5039-47aa-bcca-206a9b561bf7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiMatchAny: In scope SELECT multiMatchAny([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiMatchAny([], []);) 2025.10.23 23:31:23.243969 [ 6609 ] {dc8d2a1b-5039-47aa-bcca-206a9b561bf7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiMatchAny: In scope SELECT multiMatchAny([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:23.350007 [ 2939 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:23.434939 [ 6609 ] {d47bb129-d89b-4bd9-a09f-9c80be5bc912} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiMatchAnyIndex: In scope SELECT multiMatchAnyIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiMatchAnyIndex([], []);) 2025.10.23 23:31:23.438179 [ 6609 ] {d47bb129-d89b-4bd9-a09f-9c80be5bc912} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiMatchAnyIndex: In scope SELECT multiMatchAnyIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:23.599267 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:23.602327 [ 6609 ] {ec5c9175-cd05-4834-8be6-0172dcaeb18e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAllPositions: In scope SELECT multiSearchAllPositions([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchAllPositions([], []);) 2025.10.23 23:31:23.604937 [ 6609 ] {ec5c9175-cd05-4834-8be6-0172dcaeb18e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAllPositions: In scope SELECT multiSearchAllPositions([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:23.713191 [ 6609 ] {d2ad279e-24c1-468e-b728-15b15e840d7d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAllPositionsCaseInsensitive: In scope SELECT multiSearchAllPositionsCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitive([], []);) 2025.10.23 23:31:23.720521 [ 6609 ] {d2ad279e-24c1-468e-b728-15b15e840d7d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAllPositionsCaseInsensitive: In scope SELECT multiSearchAllPositionsCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:23.735486 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:23.803892 [ 6609 ] {4f066923-88a6-46c6-9960-08ac6e6e888d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAllPositionsCaseInsensitiveUTF8: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchAllPositionsCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:23.812256 [ 6609 ] {4f066923-88a6-46c6-9960-08ac6e6e888d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAllPositionsCaseInsensitiveUTF8: In scope SELECT multiSearchAllPositionsCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:23.872755 [ 6609 ] {7f2e01cb-8764-448e-89b3-8c3b81ee01ca} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAllPositionsUTF8: In scope SELECT multiSearchAllPositionsUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchAllPositionsUTF8([], []);) 2025.10.23 23:31:23.879643 [ 6609 ] {7f2e01cb-8764-448e-89b3-8c3b81ee01ca} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAllPositionsUTF8: In scope SELECT multiSearchAllPositionsUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:23.929667 [ 6609 ] {b8e0ab1e-e802-4de1-a5bd-d75968928634} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAny: In scope SELECT multiSearchAny([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchAny([], []);) 2025.10.23 23:31:23.934051 [ 6609 ] {b8e0ab1e-e802-4de1-a5bd-d75968928634} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAny: In scope SELECT multiSearchAny([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:23.957187 [ 2945 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:23.973541 [ 6609 ] {b656075d-57eb-4e8d-8fdb-f1eae4c304e2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAnyCaseInsensitive: In scope SELECT multiSearchAnyCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchAnyCaseInsensitive([], []);) 2025.10.23 23:31:23.978225 [ 6609 ] {b656075d-57eb-4e8d-8fdb-f1eae4c304e2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAnyCaseInsensitive: In scope SELECT multiSearchAnyCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.026798 [ 6609 ] {9f2a5833-9ae6-47ac-8e55-da1e3d1105b0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAnyCaseInsensitiveUTF8: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchAnyCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:24.031854 [ 6609 ] {9f2a5833-9ae6-47ac-8e55-da1e3d1105b0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAnyCaseInsensitiveUTF8: In scope SELECT multiSearchAnyCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.080299 [ 6609 ] {045b10ea-3b0a-4c95-acfc-7b7c7982a4c1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAnyUTF8: In scope SELECT multiSearchAnyUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchAnyUTF8([], []);) 2025.10.23 23:31:24.091489 [ 6609 ] {045b10ea-3b0a-4c95-acfc-7b7c7982a4c1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchAnyUTF8: In scope SELECT multiSearchAnyUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.135507 [ 6609 ] {4359392f-8e40-460d-a448-c1b4b6ca194f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndex: In scope SELECT multiSearchFirstIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchFirstIndex([], []);) 2025.10.23 23:31:24.143608 [ 6609 ] {4359392f-8e40-460d-a448-c1b4b6ca194f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndex: In scope SELECT multiSearchFirstIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.191158 [ 6609 ] {516b921d-6945-44b0-a38b-e6b044a6a869} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndexCaseInsensitive: In scope SELECT multiSearchFirstIndexCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitive([], []);) 2025.10.23 23:31:24.194877 [ 6609 ] {516b921d-6945-44b0-a38b-e6b044a6a869} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndexCaseInsensitive: In scope SELECT multiSearchFirstIndexCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.213987 [ 2952 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:24.262436 [ 6609 ] {12ba0f2a-3edb-4001-8069-27c0598db6db} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndexCaseInsensitiveUTF8: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchFirstIndexCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:24.280222 [ 6609 ] {12ba0f2a-3edb-4001-8069-27c0598db6db} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndexCaseInsensitiveUTF8: In scope SELECT multiSearchFirstIndexCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.352021 [ 2959 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:24.526843 [ 6609 ] {99af7a11-2fc5-4913-80cf-f48a04558f50} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndexUTF8: In scope SELECT multiSearchFirstIndexUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchFirstIndexUTF8([], []);) 2025.10.23 23:31:24.580025 [ 6609 ] {99af7a11-2fc5-4913-80cf-f48a04558f50} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstIndexUTF8: In scope SELECT multiSearchFirstIndexUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.680315 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:24.716418 [ 6609 ] {e9bfb78c-f493-47f7-89b9-1fc830ea6e72} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPosition: In scope SELECT multiSearchFirstPosition([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchFirstPosition([], []);) 2025.10.23 23:31:24.724641 [ 6609 ] {e9bfb78c-f493-47f7-89b9-1fc830ea6e72} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPosition: In scope SELECT multiSearchFirstPosition([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.796771 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:24.816669 [ 6609 ] {162e6285-ee1b-4cfe-9f7e-2579c1cd0094} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPositionCaseInsensitive: In scope SELECT multiSearchFirstPositionCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitive([], []);) 2025.10.23 23:31:24.821774 [ 6609 ] {162e6285-ee1b-4cfe-9f7e-2579c1cd0094} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPositionCaseInsensitive: In scope SELECT multiSearchFirstPositionCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.900434 [ 6609 ] {be10a74a-07d6-49b2-89a2-bc0debbf523b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPositionCaseInsensitiveUTF8: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchFirstPositionCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:24.914016 [ 6609 ] {be10a74a-07d6-49b2-89a2-bc0debbf523b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPositionCaseInsensitiveUTF8: In scope SELECT multiSearchFirstPositionCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:24.959266 [ 2968 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:25.057353 [ 6609 ] {b2286d00-5633-496c-a381-11019e0c1d52} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPositionUTF8: In scope SELECT multiSearchFirstPositionUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiSearchFirstPositionUTF8([], []);) 2025.10.23 23:31:25.061253 [ 6609 ] {b2286d00-5633-496c-a381-11019e0c1d52} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function multiSearchFirstPositionUTF8: In scope SELECT multiSearchFirstPositionUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:25.204948 [ 6609 ] {c9c73ec9-7209-4a4a-99c6-b22ebe0b1300} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function multiply: In scope SELECT [] * []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiply([], []);) 2025.10.23 23:31:25.209493 [ 6609 ] {c9c73ec9-7209-4a4a-99c6-b22ebe0b1300} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function multiply: In scope SELECT [] * []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:25.216147 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:25.265035 [ 6609 ] {d7259bda-7128-4263-abc8-69d90acd8888} executeQuery: Code: 43. DB::Exception: Arguments for multiplyDecimal function must be Decimal: In scope SELECT multiplyDecimal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT multiplyDecimal([], []);) 2025.10.23 23:31:25.269453 [ 6609 ] {d7259bda-7128-4263-abc8-69d90acd8888} TCPHandler: Code: 43. DB::Exception: Arguments for multiplyDecimal function must be Decimal: In scope SELECT multiplyDecimal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:25.354434 [ 2972 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:25.727919 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:25.842375 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:25.961626 [ 2985 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:26.218463 [ 2993 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:26.261466 [ 3621 ] {90cbb22e-eff3-427c-9518-8aec92d56568} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:26.264192 [ 3621 ] {90cbb22e-eff3-427c-9518-8aec92d56568} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:26.284302 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (3 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:26.356597 [ 2995 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:26.400248 [ 6609 ] {50e620b7-b3af-476d-b7c6-4b20d1e38441} executeQuery: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT negate([], []);) 2025.10.23 23:31:26.411663 [ 6609 ] {50e620b7-b3af-476d-b7c6-4b20d1e38441} TCPHandler: Code: 42. DB::Exception: Number of arguments for function negate doesn't match: passed 2, should be 1: In scope SELECT negate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:26.608046 [ 6609 ] {3edf50bc-7302-4545-8588-a1dfb6ee67c6} executeQuery: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT neighbor([], []);) 2025.10.23 23:31:26.619483 [ 6609 ] {3edf50bc-7302-4545-8588-a1dfb6ee67c6} TCPHandler: Code: 721. DB::Exception: Function neighbor is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.10.23 23:31:26.734139 [ 6609 ] {c5b8adae-e8a9-4d3b-8e8e-393821794e87} executeQuery: Code: 36. DB::Exception: First argument for function nested must be constant column with array of strings: In scope SELECT nested([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT nested([], []);) 2025.10.23 23:31:26.740876 [ 6609 ] {c5b8adae-e8a9-4d3b-8e8e-393821794e87} TCPHandler: Code: 36. DB::Exception: First argument for function nested must be constant column with array of strings: In scope SELECT nested([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:26.796708 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:26.832261 [ 6609 ] {40a5b838-473f-4aba-ae74-4d677c40bb80} executeQuery: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT netloc([], []);) 2025.10.23 23:31:26.843923 [ 6609 ] {40a5b838-473f-4aba-ae74-4d677c40bb80} TCPHandler: Code: 42. DB::Exception: Number of arguments for function netloc doesn't match: passed 2, should be 1: In scope SELECT netloc([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:26.918179 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:26.935286 [ 6609 ] {843620a5-5d02-48f8-8cf8-9ae4c333b421} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramDistance: In scope SELECT ngramDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramDistance([], []);) 2025.10.23 23:31:26.946738 [ 6609 ] {843620a5-5d02-48f8-8cf8-9ae4c333b421} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramDistance: In scope SELECT ngramDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:26.964500 [ 3000 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:27.038935 [ 6609 ] {06de2838-53e1-4430-bc68-ef02723a9995} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramDistanceCaseInsensitive: In scope SELECT ngramDistanceCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramDistanceCaseInsensitive([], []);) 2025.10.23 23:31:27.045782 [ 6609 ] {06de2838-53e1-4430-bc68-ef02723a9995} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramDistanceCaseInsensitive: In scope SELECT ngramDistanceCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.100440 [ 6609 ] {6a5b3dcd-7e44-44f6-8cd8-ef0fcce1e51d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramDistanceCaseInsensitiveUTF8: In scope SELECT ngramDistanceCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramDistanceCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:27.106757 [ 6609 ] {6a5b3dcd-7e44-44f6-8cd8-ef0fcce1e51d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramDistanceCaseInsensitiveUTF8: In scope SELECT ngramDistanceCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.220855 [ 3010 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:27.322736 [ 6609 ] {3ff01c19-8115-45a2-9a7c-d57184ca6180} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramDistanceUTF8: In scope SELECT ngramDistanceUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramDistanceUTF8([], []);) 2025.10.23 23:31:27.326249 [ 6609 ] {3ff01c19-8115-45a2-9a7c-d57184ca6180} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramDistanceUTF8: In scope SELECT ngramDistanceUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.359351 [ 3007 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:27.386848 [ 6609 ] {05e74517-eca2-4f0e-ad68-ac4b2c2c55ef} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nothing): In scope SELECT ngramMinHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramMinHash([], []);) 2025.10.23 23:31:27.391894 [ 6609 ] {05e74517-eca2-4f0e-ad68-ac4b2c2c55ef} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHash must be String, got Array(Nothing): In scope SELECT ngramMinHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.497731 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:27.505316 [ 6609 ] {1a38387c-f8e8-41c6-af45-2c8f09c6bba1} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nothing): In scope SELECT ngramMinHashArg([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramMinHashArg([], []);) 2025.10.23 23:31:27.514349 [ 6609 ] {1a38387c-f8e8-41c6-af45-2c8f09c6bba1} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArg must be String, got Array(Nothing): In scope SELECT ngramMinHashArg([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.647692 [ 6609 ] {d00bc403-4b91-4a14-806f-e2583b9c6731} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramMinHashArgCaseInsensitive([], []);) 2025.10.23 23:31:27.658671 [ 6609 ] {d00bc403-4b91-4a14-806f-e2583b9c6731} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.687637 [ 3386 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_91_106_3}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:27.745381 [ 6609 ] {53f03eaf-5b2a-4630-bc85-2f892bfc9ba2} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramMinHashArgCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:27.755133 [ 6609 ] {53f03eaf-5b2a-4630-bc85-2f892bfc9ba2} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.837270 [ 6609 ] {d7341a7c-b432-4a83-86a8-a75746d12564} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramMinHashArgUTF8([], []);) 2025.10.23 23:31:27.842888 [ 6609 ] {d7341a7c-b432-4a83-86a8-a75746d12564} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashArgUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.850371 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:27.955515 [ 6609 ] {22fdc3ac-0fb9-4ee8-ae04-1ae9daf22e17} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramMinHashCaseInsensitive([], []);) 2025.10.23 23:31:27.959482 [ 6609 ] {22fdc3ac-0fb9-4ee8-ae04-1ae9daf22e17} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:27.966950 [ 3022 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:28.015147 [ 6609 ] {324f8cca-7a3c-44bd-b92a-09ca8d01614c} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramMinHashCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:28.025521 [ 6609 ] {324f8cca-7a3c-44bd-b92a-09ca8d01614c} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.051877 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:28.103038 [ 6609 ] {89621bda-152a-4647-ba28-5146957b94cc} executeQuery: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramMinHashUTF8([], []);) 2025.10.23 23:31:28.110417 [ 6609 ] {89621bda-152a-4647-ba28-5146957b94cc} TCPHandler: Code: 43. DB::Exception: First argument of function ngramMinHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramMinHashUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.194641 [ 6609 ] {58066177-f720-4ca0-adcc-1cef79d35025} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramSearch: In scope SELECT ngramSearch([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramSearch([], []);) 2025.10.23 23:31:28.205774 [ 6609 ] {58066177-f720-4ca0-adcc-1cef79d35025} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramSearch: In scope SELECT ngramSearch([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.223500 [ 3025 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:28.253023 [ 6609 ] {ae094338-5e97-457e-96eb-315a760cd253} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramSearchCaseInsensitive: In scope SELECT ngramSearchCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramSearchCaseInsensitive([], []);) 2025.10.23 23:31:28.256924 [ 6609 ] {ae094338-5e97-457e-96eb-315a760cd253} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramSearchCaseInsensitive: In scope SELECT ngramSearchCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.295399 [ 3381 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ea299d1d-6a64-4384-9014-89925bfc5db4::202510_1_44_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:28.305146 [ 6609 ] {d3b22f6b-707f-4987-b4eb-0c294422de57} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramSearchCaseInsensitiveUTF8: In scope SELECT ngramSearchCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramSearchCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:28.311447 [ 6609 ] {d3b22f6b-707f-4987-b4eb-0c294422de57} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramSearchCaseInsensitiveUTF8: In scope SELECT ngramSearchCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.361505 [ 3026 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:28.379358 [ 6609 ] {d7f949d9-473e-4ab5-b9d6-73848b658adb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramSearchUTF8: In scope SELECT ngramSearchUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramSearchUTF8([], []);) 2025.10.23 23:31:28.396177 [ 6609 ] {d7f949d9-473e-4ab5-b9d6-73848b658adb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function ngramSearchUTF8: In scope SELECT ngramSearchUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.442999 [ 6609 ] {b3000cc3-76e4-4b9a-8096-442388308764} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nothing): In scope SELECT ngramSimHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramSimHash([], []);) 2025.10.23 23:31:28.448106 [ 6609 ] {b3000cc3-76e4-4b9a-8096-442388308764} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHash must be String, got Array(Nothing): In scope SELECT ngramSimHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.523180 [ 6609 ] {d1a651ba-c83b-4cbc-9b28-64ed988af259} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramSimHashCaseInsensitive([], []);) 2025.10.23 23:31:28.575686 [ 3385 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c1299da-d909-4b7c-85cc-168a8083c3c9::202510_1_45_9}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:28.609459 [ 6609 ] {d1a651ba-c83b-4cbc-9b28-64ed988af259} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.805495 [ 6609 ] {5a673f2f-b863-4668-beb4-cdcc26ae472e} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramSimHashCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:28.825104 [ 6609 ] {5a673f2f-b863-4668-beb4-cdcc26ae472e} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.910798 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:28.929283 [ 6609 ] {98d83380-5fc5-435b-bca8-78e5cb6f43ea} executeQuery: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngramSimHashUTF8([], []);) 2025.10.23 23:31:28.938953 [ 6609 ] {98d83380-5fc5-435b-bca8-78e5cb6f43ea} TCPHandler: Code: 43. DB::Exception: First argument of function ngramSimHashUTF8 must be String, got Array(Nothing): In scope SELECT ngramSimHashUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:28.969006 [ 3047 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:29.041103 [ 6609 ] {90415186-720e-499f-834b-1627abc68838} executeQuery: Code: 36. DB::Exception: Function ngrams first argument type should be String or FixedString. Actual Array(Nothing): In scope SELECT ngrams([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ngrams([], []);) 2025.10.23 23:31:29.045611 [ 6609 ] {90415186-720e-499f-834b-1627abc68838} TCPHandler: Code: 36. DB::Exception: Function ngrams first argument type should be String or FixedString. Actual Array(Nothing): In scope SELECT ngrams([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:29.088033 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:29.192634 [ 6609 ] {cf80875f-e4fe-4f5f-a97d-b2da9d46778f} executeQuery: Code: 36. DB::Exception: Argument 0 must be a number, 'Array(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT nonNegativeDerivative([], []);) 2025.10.23 23:31:29.197365 [ 6609 ] {cf80875f-e4fe-4f5f-a97d-b2da9d46778f} TCPHandler: Code: 36. DB::Exception: Argument 0 must be a number, 'Array(Nothing)' given. (BAD_ARGUMENTS) 2025.10.23 23:31:29.225671 [ 3055 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:29.363710 [ 3061 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:29.401435 [ 6609 ] {4139b490-184f-4435-bec6-0278df34d110} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normL1([], []);) 2025.10.23 23:31:29.404523 [ 6609 ] {4139b490-184f-4435-bec6-0278df34d110} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Norm doesn't match: passed 2, should be 1: In scope SELECT normL1([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:29.457910 [ 6609 ] {385d2d60-772b-4e20-98fd-0fc26fca337d} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normL2([], []);) 2025.10.23 23:31:29.470762 [ 6609 ] {385d2d60-772b-4e20-98fd-0fc26fca337d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Norm doesn't match: passed 2, should be 1: In scope SELECT normL2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:29.535225 [ 6609 ] {70faaccd-e24d-491f-a0dd-40c6e3c4766a} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normL2Squared([], []);) 2025.10.23 23:31:29.542514 [ 6609 ] {70faaccd-e24d-491f-a0dd-40c6e3c4766a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2SquaredNorm doesn't match: passed 2, should be 1: In scope SELECT normL2Squared([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:29.616998 [ 6609 ] {996bd476-b9ac-4284-b3dd-d9cd45f142f7} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normLinf([], []);) 2025.10.23 23:31:29.632106 [ 6609 ] {996bd476-b9ac-4284-b3dd-d9cd45f142f7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNorm doesn't match: passed 2, should be 1: In scope SELECT normLinf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:29.742885 [ 6609 ] {2b0ecbc3-252c-47e2-acbe-65eaa382abf5} executeQuery: Code: 43. DB::Exception: Arguments of function arrayLpNorm has nested type Nothing. Support: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT normLp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normLp([], []);) 2025.10.23 23:31:29.748166 [ 6609 ] {2b0ecbc3-252c-47e2-acbe-65eaa382abf5} TCPHandler: Code: 43. DB::Exception: Arguments of function arrayLpNorm has nested type Nothing. Support: UInt8, UInt16, UInt32, UInt64, Int8, Int16, Int32, Int64, Float32, Float64.: In scope SELECT normLp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:29.906297 [ 6609 ] {6c3c7c7c-42b4-4bd6-9f40-fcdaaffff447} executeQuery: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeL1([], []);) 2025.10.23 23:31:29.915027 [ 6609 ] {6c3c7c7c-42b4-4bd6-9f40-fcdaaffff447} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L1Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL1([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:29.954464 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:29.971056 [ 3080 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:30.071143 [ 6609 ] {ab1b68b9-84cf-4aa4-942a-974aaea86ec1} executeQuery: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeL2([], []);) 2025.10.23 23:31:30.074666 [ 6609 ] {ab1b68b9-84cf-4aa4-942a-974aaea86ec1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function L2Normalize doesn't match: passed 2, should be 1: In scope SELECT normalizeL2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.094676 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:30.207427 [ 6609 ] {259cd04f-c018-4ba5-94c3-8ff9cc6079dc} executeQuery: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeLinf([], []);) 2025.10.23 23:31:30.215194 [ 6609 ] {259cd04f-c018-4ba5-94c3-8ff9cc6079dc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function LinfNormalize doesn't match: passed 2, should be 1: In scope SELECT normalizeLinf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.227750 [ 3085 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:30.261488 [ 6609 ] {28c23456-76ed-4de8-b9ae-565c483bb7d0} executeQuery: Code: 43. DB::Exception: Argument 0 of function LpNorm should be tuple, got Array(Nothing): In scope SELECT normalizeLp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeLp([], []);) 2025.10.23 23:31:30.265275 [ 6609 ] {28c23456-76ed-4de8-b9ae-565c483bb7d0} TCPHandler: Code: 43. DB::Exception: Argument 0 of function LpNorm should be tuple, got Array(Nothing): In scope SELECT normalizeLp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:30.305925 [ 6609 ] {c0badffd-f328-43c3-a27a-21666c0e2cf1} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeQuery([], []);) 2025.10.23 23:31:30.321197 [ 6609 ] {c0badffd-f328-43c3-a27a-21666c0e2cf1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQuery doesn't match: passed 2, should be 1: In scope SELECT normalizeQuery([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.365661 [ 3090 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:30.375089 [ 6609 ] {bef14a88-f7b5-4785-aba9-3f350c678da6} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeQueryKeepNames([], []);) 2025.10.23 23:31:30.381938 [ 6609 ] {bef14a88-f7b5-4785-aba9-3f350c678da6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeQueryKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizeQueryKeepNames([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.445958 [ 6609 ] {e4affba6-3b0b-4115-8036-c87dacda806b} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeUTF8NFC([], []);) 2025.10.23 23:31:30.449534 [ 6609 ] {e4affba6-3b0b-4115-8036-c87dacda806b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.499169 [ 6609 ] {72a9b0d7-e626-47f4-8866-dfbe9495aa09} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeUTF8NFD([], []);) 2025.10.23 23:31:30.503962 [ 6609 ] {72a9b0d7-e626-47f4-8866-dfbe9495aa09} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFD([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.560940 [ 6609 ] {621621ab-1548-4c5d-80f3-efd76c6de85c} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeUTF8NFKC([], []);) 2025.10.23 23:31:30.571879 [ 6609 ] {621621ab-1548-4c5d-80f3-efd76c6de85c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKC doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.658606 [ 6609 ] {7bfb397e-2669-49cf-9a10-386b28df959c} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizeUTF8NFKD([], []);) 2025.10.23 23:31:30.667554 [ 6609 ] {7bfb397e-2669-49cf-9a10-386b28df959c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizeUTF8NFKD doesn't match: passed 2, should be 1: In scope SELECT normalizeUTF8NFKD([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.768779 [ 6609 ] {547dfbd3-7b24-44dc-9c97-5a0de8501591} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizedQueryHash([], []);) 2025.10.23 23:31:30.779406 [ 6609 ] {547dfbd3-7b24-44dc-9c97-5a0de8501591} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHash doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHash([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:30.965263 [ 6609 ] {afa89647-2210-4b20-a5df-6ef8e12bfd53} executeQuery: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT normalizedQueryHashKeepNames([], []);) 2025.10.23 23:31:30.973002 [ 3102 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:30.978828 [ 6609 ] {afa89647-2210-4b20-a5df-6ef8e12bfd53} TCPHandler: Code: 42. DB::Exception: Number of arguments for function normalizedQueryHashKeepNames doesn't match: passed 2, should be 1: In scope SELECT normalizedQueryHashKeepNames([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:31.000830 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:31.092048 [ 6609 ] {458d40ec-e5ad-4230-8866-902f6e26c09f} executeQuery: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT not([], []);) 2025.10.23 23:31:31.098010 [ 6609 ] {458d40ec-e5ad-4230-8866-902f6e26c09f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function not doesn't match: passed 2, should be 1: In scope SELECT not([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:31.133382 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:31.168433 [ 6609 ] {0b3ce1da-985d-4969-933d-81fb7cd52c16} executeQuery: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT notEmpty([], []);) 2025.10.23 23:31:31.178204 [ 6609 ] {0b3ce1da-985d-4969-933d-81fb7cd52c16} TCPHandler: Code: 42. DB::Exception: Number of arguments for function notEmpty doesn't match: passed 2, should be 1: In scope SELECT notEmpty([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:31.229729 [ 3104 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:31.323375 [ 6609 ] {ef7d0d80-e091-4961-a475-ba337c8f99e9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function notILike: In scope SELECT [] NOT ILIKE []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT notILike([], []);) 2025.10.23 23:31:31.327947 [ 6609 ] {ef7d0d80-e091-4961-a475-ba337c8f99e9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function notILike: In scope SELECT [] NOT ILIKE []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:31.368123 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:31.455671 [ 3621 ] {98fb993a-6113-456d-8709-807b0d6b216a} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:31.458748 [ 3621 ] {98fb993a-6113-456d-8709-807b0d6b216a} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:31.470017 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (4 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:31.573342 [ 6609 ] {fe5a416a-c089-4964-8647-5612975a5b98} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function notLike: In scope SELECT [] NOT LIKE []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT notLike([], []);) 2025.10.23 23:31:31.577259 [ 6609 ] {fe5a416a-c089-4964-8647-5612975a5b98} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function notLike: In scope SELECT [] NOT LIKE []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:31.977666 [ 3124 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:32.026240 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:32.137199 [ 6609 ] {e2098ab1-cfa7-4ec5-b58d-d1af2293dc5e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT nothing([], []);) 2025.10.23 23:31:32.139267 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:32.231738 [ 3125 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:32.238811 [ 6609 ] {e2098ab1-cfa7-4ec5-b58d-d1af2293dc5e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:31:32.370583 [ 3130 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:32.588785 [ 6609 ] {9e220fe5-c273-41be-b1d6-8e96cc4ea006} executeQuery: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT now([], []);) 2025.10.23 23:31:32.593936 [ 6609 ] {9e220fe5-c273-41be-b1d6-8e96cc4ea006} TCPHandler: Code: 42. DB::Exception: Arguments size of function now should be 0 or 1: In scope SELECT now([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:32.594407 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:32.661012 [ 6609 ] {e47d4775-36b8-460e-9823-9c9ed16cef97} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 0 argument of function now64. Expected const integer.: In scope SELECT now64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT now64([], []);) 2025.10.23 23:31:32.671153 [ 6609 ] {e47d4775-36b8-460e-9823-9c9ed16cef97} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 0 argument of function now64. Expected const integer.: In scope SELECT now64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:32.717302 [ 6609 ] {443ddd42-8381-4f12-a78b-1051b3ab87e7} executeQuery: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock([], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT nowInBlock([], []);) 2025.10.23 23:31:32.723083 [ 6609 ] {443ddd42-8381-4f12-a78b-1051b3ab87e7} TCPHandler: Code: 34. DB::Exception: Arguments size of function nowInBlock should be 0 or 1: In scope SELECT nowInBlock([], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.10.23 23:31:32.884117 [ 6609 ] {139b9eb7-2299-495b-96dc-d71f00d25c51} executeQuery: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT nth_value([], []);) 2025.10.23 23:31:32.900419 [ 6609 ] {139b9eb7-2299-495b-96dc-d71f00d25c51} TCPHandler: Code: 36. DB::Exception: Offset must be an integer, 'Array(Nothing)' given. (BAD_ARGUMENTS) 2025.10.23 23:31:32.979888 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:33.009234 [ 6609 ] {1072ee28-e07b-4b20-8345-5f04683e89ef} executeQuery: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ntile([], []);) 2025.10.23 23:31:33.014539 [ 6609 ] {1072ee28-e07b-4b20-8345-5f04683e89ef} TCPHandler: Code: 42. DB::Exception: Function ntile takes exactly one argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:33.061099 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:33.081012 [ 6609 ] {0aded058-dac6-4097-8687-6eadea666a5a} executeQuery: Code: 43. DB::Exception: Nested type Array(Nothing) cannot be inside Nullable type: In scope SELECT nullIf([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT nullIf([], []);) 2025.10.23 23:31:33.088628 [ 6609 ] {0aded058-dac6-4097-8687-6eadea666a5a} TCPHandler: Code: 43. DB::Exception: Nested type Array(Nothing) cannot be inside Nullable type: In scope SELECT nullIf([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:33.178388 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:33.233931 [ 3143 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:33.373240 [ 3145 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:33.391421 [ 6609 ] {4707f2e3-a6b2-4518-a184-c7e996f9662e} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function or: In scope SELECT [] OR []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT or([], []);) 2025.10.23 23:31:33.396633 [ 6609 ] {4707f2e3-a6b2-4518-a184-c7e996f9662e} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function or: In scope SELECT [] OR []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:33.456921 [ 6609 ] {a6bfcdd6-fd2d-4460-909f-e74b7bf3dc89} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime([], []);) 2025.10.23 23:31:33.461355 [ 6609 ] {a6bfcdd6-fd2d-4460-909f-e74b7bf3dc89} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTime'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:33.507786 [ 6609 ] {0e646672-d143-4875-8f00-9e9d523b23d0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffort: In scope SELECT parseDateTime32BestEffort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime32BestEffort([], []);) 2025.10.23 23:31:33.512666 [ 6609 ] {0e646672-d143-4875-8f00-9e9d523b23d0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffort: In scope SELECT parseDateTime32BestEffort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:33.569407 [ 6609 ] {51b321d7-d6e7-4de7-aebd-d5e87f7af5b3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime32BestEffortOrNull([], []);) 2025.10.23 23:31:33.574028 [ 6609 ] {51b321d7-d6e7-4de7-aebd-d5e87f7af5b3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:33.628368 [ 6609 ] {875d2e1c-eb3b-4e6d-ba67-6ec443ef55b6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime32BestEffortOrZero([], []);) 2025.10.23 23:31:33.633915 [ 6609 ] {875d2e1c-eb3b-4e6d-ba67-6ec443ef55b6} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTime32BestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTime32BestEffortOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:33.698816 [ 6609 ] {0820e604-2786-4930-8d95-c1b2decba764} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime64BestEffort([], []);) 2025.10.23 23:31:33.705143 [ 6609 ] {0820e604-2786-4930-8d95-c1b2decba764} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffort'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:33.785326 [ 6609 ] {ad4249fe-25ab-4f3f-8502-76d1ed5adc7f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime64BestEffortOrNull([], []);) 2025.10.23 23:31:33.805200 [ 6609 ] {ad4249fe-25ab-4f3f-8502-76d1ed5adc7f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:33.982073 [ 3157 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:33.995981 [ 6609 ] {080ad275-534a-4f7b-8c8d-c51dece090ae} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime64BestEffortOrZero([], []);) 2025.10.23 23:31:34.008448 [ 6609 ] {080ad275-534a-4f7b-8c8d-c51dece090ae} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.092327 [ 6609 ] {49084fdc-e8ea-449f-8204-690c3d705b28} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUS([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime64BestEffortUS([], []);) 2025.10.23 23:31:34.105351 [ 6609 ] {49084fdc-e8ea-449f-8204-690c3d705b28} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUS'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUS([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.133979 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:34.236551 [ 3159 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:34.244108 [ 6609 ] {78cae39b-e9f5-42de-9d83-26841980decd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime64BestEffortUSOrNull([], []);) 2025.10.23 23:31:34.248205 [ 6609 ] {78cae39b-e9f5-42de-9d83-26841980decd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.279159 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:34.325369 [ 6609 ] {bcc590ba-e3ce-4baf-8714-60dae22c583d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTime64BestEffortUSOrZero([], []);) 2025.10.23 23:31:34.337316 [ 6609 ] {bcc590ba-e3ce-4baf-8714-60dae22c583d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'parseDateTime64BestEffortUSOrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT parseDateTime64BestEffortUSOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.375581 [ 3160 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:34.435932 [ 6609 ] {09c9d052-227f-401c-bddc-fad1aadb695c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffort: In scope SELECT parseDateTimeBestEffort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeBestEffort([], []);) 2025.10.23 23:31:34.440375 [ 6609 ] {09c9d052-227f-401c-bddc-fad1aadb695c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffort: In scope SELECT parseDateTimeBestEffort([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.489165 [ 6609 ] {76e66825-e481-42fc-90c5-5a63b745d8e3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeBestEffortOrNull([], []);) 2025.10.23 23:31:34.497463 [ 6609 ] {76e66825-e481-42fc-90c5-5a63b745d8e3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.569322 [ 6609 ] {ad11e011-26f1-419c-80a3-560ff28c7524} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeBestEffortOrZero([], []);) 2025.10.23 23:31:34.664275 [ 6609 ] {ad11e011-26f1-419c-80a3-560ff28c7524} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.744270 [ 6609 ] {ffc3dfdd-dfd8-4431-92fa-2dc4cb7a905a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUS: In scope SELECT parseDateTimeBestEffortUS([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeBestEffortUS([], []);) 2025.10.23 23:31:34.750854 [ 6609 ] {ffc3dfdd-dfd8-4431-92fa-2dc4cb7a905a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUS: In scope SELECT parseDateTimeBestEffortUS([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.857058 [ 6609 ] {9b367df1-a506-49fd-af97-903b60e64b20} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUSOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeBestEffortUSOrNull([], []);) 2025.10.23 23:31:34.869386 [ 6609 ] {9b367df1-a506-49fd-af97-903b60e64b20} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUSOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:34.984246 [ 6609 ] {e98d2143-3959-4d59-a115-b66450664d7c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUSOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeBestEffortUSOrZero([], []);) 2025.10.23 23:31:34.984257 [ 3174 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:34.989623 [ 6609 ] {e98d2143-3959-4d59-a115-b66450664d7c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function parseDateTimeBestEffortUSOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT parseDateTimeBestEffortUSOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:35.109466 [ 6609 ] {8fb39d36-3bea-4c6f-8388-51ddf14ec3a5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntax([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeInJodaSyntax([], []);) 2025.10.23 23:31:35.121162 [ 6609 ] {8fb39d36-3bea-4c6f-8388-51ddf14ec3a5} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntax'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntax([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:35.166238 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:35.239001 [ 3178 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:35.262370 [ 6609 ] {859d7e96-b29a-4593-869e-db8f0594b2d3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeInJodaSyntaxOrNull([], []);) 2025.10.23 23:31:35.276763 [ 6609 ] {859d7e96-b29a-4593-869e-db8f0594b2d3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:35.342337 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:35.350334 [ 6609 ] {528cde57-e4f9-4031-a3c4-6f15c6e3a1a2} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeInJodaSyntaxOrZero([], []);) 2025.10.23 23:31:35.373088 [ 6609 ] {528cde57-e4f9-4031-a3c4-6f15c6e3a1a2} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeInJodaSyntaxOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeInJodaSyntaxOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:35.379791 [ 3180 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:35.465103 [ 6609 ] {f9e608a8-29bd-4391-8b81-d5ebf8d8a244} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeOrNull([], []);) 2025.10.23 23:31:35.471164 [ 6609 ] {f9e608a8-29bd-4391-8b81-d5ebf8d8a244} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:35.530903 [ 6609 ] {f2d04050-1ddf-47d8-ae4f-8b3dd827a237} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseDateTimeOrZero([], []);) 2025.10.23 23:31:35.534628 [ 6609 ] {f2d04050-1ddf-47d8-ae4f-8b3dd827a237} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrZero'. Expected: String, got: Array(Nothing): In scope SELECT parseDateTimeOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:35.615543 [ 6609 ] {a699e13e-19d0-41b5-987d-51538ffd9717} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseReadableSize([], []);) 2025.10.23 23:31:35.620987 [ 6609 ] {a699e13e-19d0-41b5-987d-51538ffd9717} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSize doesn't match: passed 2, should be 1: In scope SELECT parseReadableSize([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:35.663593 [ 6609 ] {32739ab5-02ea-4408-ba72-67058684ec6c} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseReadableSizeOrNull([], []);) 2025.10.23 23:31:35.668119 [ 6609 ] {32739ab5-02ea-4408-ba72-67058684ec6c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrNull doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:35.709877 [ 6609 ] {f821601e-c08c-4a8a-8ff2-e669adedb338} executeQuery: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseReadableSizeOrZero([], []);) 2025.10.23 23:31:35.727231 [ 6609 ] {f821601e-c08c-4a8a-8ff2-e669adedb338} TCPHandler: Code: 42. DB::Exception: Number of arguments for function parseReadableSizeOrZero doesn't match: passed 2, should be 1: In scope SELECT parseReadableSizeOrZero([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:35.813423 [ 6609 ] {568ca005-e483-472a-8723-8481219c82a6} executeQuery: Code: 34. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 2, should be 1.: In scope SELECT parseTimeDelta([], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT parseTimeDelta([], []);) 2025.10.23 23:31:35.829131 [ 6609 ] {568ca005-e483-472a-8723-8481219c82a6} TCPHandler: Code: 34. DB::Exception: Number of arguments for function parseTimeDelta doesn't match: passed 2, should be 1.: In scope SELECT parseTimeDelta([], []). (TOO_MANY_ARGUMENTS_FOR_FUNCTION) 2025.10.23 23:31:35.986931 [ 3175 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:36.240980 [ 3201 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:36.243962 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:36.252080 [ 6609 ] {694aff3a-bde4-4449-88be-2b270a359441} executeQuery: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT path([], []);) 2025.10.23 23:31:36.260643 [ 6609 ] {694aff3a-bde4-4449-88be-2b270a359441} TCPHandler: Code: 42. DB::Exception: Number of arguments for function path doesn't match: passed 2, should be 1: In scope SELECT path([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:36.364904 [ 6609 ] {a27acac2-3ec2-4af2-b0c4-d491f4f7ac9e} executeQuery: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT pathFull([], []);) 2025.10.23 23:31:36.369211 [ 6609 ] {a27acac2-3ec2-4af2-b0c4-d491f4f7ac9e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pathFull doesn't match: passed 2, should be 1: In scope SELECT pathFull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:36.381919 [ 3202 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:36.448241 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:36.517838 [ 6609 ] {402bc17a-1bac-4e88-a877-be343b0ebab8} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT percentRank([], []);) 2025.10.23 23:31:36.529681 [ 6609 ] {402bc17a-1bac-4e88-a877-be343b0ebab8} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:31:36.729846 [ 6609 ] {fa7d8d13-5f25-4e59-917e-2df328b7cc61} executeQuery: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT percent_rank([], []);) 2025.10.23 23:31:36.737573 [ 6609 ] {fa7d8d13-5f25-4e59-917e-2df328b7cc61} TCPHandler: Code: 36. DB::Exception: The function 'percentRank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:31:36.790484 [ 6609 ] {3c7d4b36-cc05-4cd0-b8b2-43a5158a4710} executeQuery: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT pi([], []);) 2025.10.23 23:31:36.794354 [ 6609 ] {3c7d4b36-cc05-4cd0-b8b2-43a5158a4710} TCPHandler: Code: 42. DB::Exception: Number of arguments for function pi doesn't match: passed 2, should be 0: In scope SELECT pi([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:36.842469 [ 6609 ] {5af857cb-1d5a-4c35-b121-380141c07c5a} executeQuery: Code: 43. DB::Exception: Illegal types Nothing and Nothing of arguments of function plus: In scope SELECT [] + []. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT plus([], []);) 2025.10.23 23:31:36.847464 [ 6609 ] {5af857cb-1d5a-4c35-b121-380141c07c5a} TCPHandler: Code: 43. DB::Exception: Illegal types Nothing and Nothing of arguments of function plus: In scope SELECT [] + []. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:36.851655 [ 3621 ] {89252ffb-34a4-4f3b-8035-15e83d0f1f58} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:36.860362 [ 3621 ] {89252ffb-34a4-4f3b-8035-15e83d0f1f58} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:36.869923 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (5 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:36.917329 [ 6609 ] {cfd5db22-49ac-4e74-8ce9-051622e7048c} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function positiveModulo: In scope SELECT pmod([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT pmod([], []);) 2025.10.23 23:31:36.927828 [ 6609 ] {cfd5db22-49ac-4e74-8ce9-051622e7048c} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function positiveModulo: In scope SELECT pmod([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:36.988901 [ 3213 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:37.006519 [ 6609 ] {5bb98bc3-3178-412d-8e84-02748149f307} executeQuery: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT pointInEllipses([], []);) 2025.10.23 23:31:37.017036 [ 6609 ] {5bb98bc3-3178-412d-8e84-02748149f307} TCPHandler: Code: 42. DB::Exception: Incorrect number of arguments of function pointInEllipses. Must be 2 for your point plus 4 * N for ellipses (x_i, y_i, a_i, b_i).: In scope SELECT pointInEllipses([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:37.153836 [ 6609 ] {a681c3b1-bfdf-4b07-995b-69b6b8cbfd5c} executeQuery: Code: 43. DB::Exception: Argument 1 for function pointInPolygon must contain a tuple: In scope SELECT pointInPolygon([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT pointInPolygon([], []);) 2025.10.23 23:31:37.159000 [ 6609 ] {a681c3b1-bfdf-4b07-995b-69b6b8cbfd5c} TCPHandler: Code: 43. DB::Exception: Argument 1 for function pointInPolygon must contain a tuple: In scope SELECT pointInPolygon([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:37.244912 [ 3220 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:37.316856 [ 6609 ] {a07da6c9-5448-4660-a692-4e025e388b1b} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonAreaCartesian([], []);) 2025.10.23 23:31:37.326070 [ 6609 ] {a07da6c9-5448-4660-a692-4e025e388b1b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonAreaCartesian([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:37.353419 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:37.383789 [ 3222 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:37.495855 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:37.547531 [ 6609 ] {e1a8c7c9-0763-46db-888f-c48fafdcc49e} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonAreaSpherical([], []);) 2025.10.23 23:31:37.549919 [ 6609 ] {e1a8c7c9-0763-46db-888f-c48fafdcc49e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonAreaSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonAreaSpherical([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:37.615070 [ 6609 ] {994c9935-ca32-4251-aa49-bdad68e40f60} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonConvexHullCartesian([], []);) 2025.10.23 23:31:37.619747 [ 6609 ] {994c9935-ca32-4251-aa49-bdad68e40f60} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonConvexHullCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonConvexHullCartesian([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:37.654074 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:37.673686 [ 6609 ] {16afd1e1-3274-4558-a4c3-e167a01fac2a} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonPerimeterCartesian([], []);) 2025.10.23 23:31:37.681285 [ 6609 ] {16afd1e1-3274-4558-a4c3-e167a01fac2a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterCartesian doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterCartesian([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:37.738696 [ 6609 ] {2a835fb0-3c8b-472c-b1a5-8acf524cd3f4} executeQuery: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonPerimeterSpherical([], []);) 2025.10.23 23:31:37.743963 [ 6609 ] {2a835fb0-3c8b-472c-b1a5-8acf524cd3f4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function polygonPerimeterSpherical doesn't match: passed 2, should be 1: In scope SELECT polygonPerimeterSpherical([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:37.805684 [ 6609 ] {d94d14ee-2e9b-4474-b9be-ecda0109d92b} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsDistanceCartesian([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsDistanceCartesian([], []);) 2025.10.23 23:31:37.809979 [ 6609 ] {d94d14ee-2e9b-4474-b9be-ecda0109d92b} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsDistanceCartesian([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:37.866657 [ 6609 ] {b827435a-fc70-4142-afc3-caf649995c1e} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsDistanceSpherical([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsDistanceSpherical([], []);) 2025.10.23 23:31:37.872611 [ 6609 ] {b827435a-fc70-4142-afc3-caf649995c1e} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsDistanceSpherical([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:37.928726 [ 6609 ] {32e39c08-96fa-497b-8a48-c3551fe11cdd} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsEqualsCartesian([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsEqualsCartesian([], []);) 2025.10.23 23:31:37.933488 [ 6609 ] {32e39c08-96fa-497b-8a48-c3551fe11cdd} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsEqualsCartesian([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:37.993361 [ 3233 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:38.008694 [ 6609 ] {87616fed-8786-4421-8191-b0534419c2a2} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsIntersectionCartesian([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsIntersectionCartesian([], []);) 2025.10.23 23:31:38.013114 [ 6609 ] {87616fed-8786-4421-8191-b0534419c2a2} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsIntersectionCartesian([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:38.157061 [ 6609 ] {609ccfff-66e3-4abf-809a-d992ca517a77} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsIntersectionSpherical([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsIntersectionSpherical([], []);) 2025.10.23 23:31:38.159822 [ 6609 ] {609ccfff-66e3-4abf-809a-d992ca517a77} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsIntersectionSpherical([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:38.295518 [ 3248 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:38.319901 [ 6609 ] {deef1eb3-a1d8-4856-b8d0-1fcaa8b1cca7} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsSymDifferenceCartesian([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsSymDifferenceCartesian([], []);) 2025.10.23 23:31:38.328969 [ 6609 ] {deef1eb3-a1d8-4856-b8d0-1fcaa8b1cca7} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsSymDifferenceCartesian([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:38.385683 [ 3241 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:38.447457 [ 6609 ] {ee0c987a-c07b-4ccc-929a-43dba0da7a4e} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsSymDifferenceSpherical([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsSymDifferenceSpherical([], []);) 2025.10.23 23:31:38.456011 [ 6609 ] {ee0c987a-c07b-4ccc-929a-43dba0da7a4e} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsSymDifferenceSpherical([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:38.464708 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:38.517346 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:38.580804 [ 6609 ] {ef2e9619-16fc-4320-a021-a9dcf671d8b0} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsUnionCartesian([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsUnionCartesian([], []);) 2025.10.23 23:31:38.589796 [ 6609 ] {ef2e9619-16fc-4320-a021-a9dcf671d8b0} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsUnionCartesian([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:38.675162 [ 6609 ] {853ca436-5c36-4c9f-9a49-05985d6c1dba} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsUnionSpherical([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsUnionSpherical([], []);) 2025.10.23 23:31:38.680390 [ 6609 ] {853ca436-5c36-4c9f-9a49-05985d6c1dba} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsUnionSpherical([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:38.741774 [ 6609 ] {0279afb2-e14d-497c-aaad-c0e57733eff8} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsWithinCartesian([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsWithinCartesian([], []);) 2025.10.23 23:31:38.746629 [ 6609 ] {0279afb2-e14d-497c-aaad-c0e57733eff8} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsWithinCartesian([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:38.799727 [ 6609 ] {7596f5fe-0884-44bb-9ff0-58abd34b32ef} executeQuery: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsWithinSpherical([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT polygonsWithinSpherical([], []);) 2025.10.23 23:31:38.803994 [ 6609 ] {7596f5fe-0884-44bb-9ff0-58abd34b32ef} TCPHandler: Code: 36. DB::Exception: Unknown geometry type Array(Nothing): In scope SELECT polygonsWithinSpherical([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:38.851342 [ 6609 ] {5b24e642-b575-4a71-b615-ba3b7e521844} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function port. Must be String.: In scope SELECT port([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT port([], []);) 2025.10.23 23:31:38.855221 [ 6609 ] {5b24e642-b575-4a71-b615-ba3b7e521844} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function port. Must be String.: In scope SELECT port([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:38.911653 [ 6609 ] {d829d45b-c2eb-43f4-ac29-1b69d60ad2f6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function portRFC. Must be String.: In scope SELECT portRFC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT portRFC([], []);) 2025.10.23 23:31:38.916238 [ 6609 ] {d829d45b-c2eb-43f4-ac29-1b69d60ad2f6} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function portRFC. Must be String.: In scope SELECT portRFC([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:38.965379 [ 6609 ] {2080669c-7e10-4151-9e3e-28d77c8f7697} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function position: In scope SELECT position([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT position([], []);) 2025.10.23 23:31:38.968546 [ 6609 ] {2080669c-7e10-4151-9e3e-28d77c8f7697} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function position: In scope SELECT position([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:38.995589 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:39.018004 [ 6609 ] {58ec008e-c87f-4326-a027-b16c9bd71e23} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitive: In scope SELECT positionCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT positionCaseInsensitive([], []);) 2025.10.23 23:31:39.023103 [ 6609 ] {58ec008e-c87f-4326-a027-b16c9bd71e23} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitive: In scope SELECT positionCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:39.086226 [ 6609 ] {390f9fd7-037d-4d71-ad92-afe05648d347} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitiveUTF8: In scope SELECT positionCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT positionCaseInsensitiveUTF8([], []);) 2025.10.23 23:31:39.093300 [ 6609 ] {390f9fd7-037d-4d71-ad92-afe05648d347} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionCaseInsensitiveUTF8: In scope SELECT positionCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:39.201286 [ 6609 ] {b18c134a-adac-435a-925d-4ebc7261aa1d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionUTF8: In scope SELECT positionUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT positionUTF8([], []);) 2025.10.23 23:31:39.209212 [ 6609 ] {b18c134a-adac-435a-925d-4ebc7261aa1d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function positionUTF8: In scope SELECT positionUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:39.297871 [ 3254 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:39.331515 [ 6609 ] {aed0d33c-7abb-4f76-982b-e164fae3cf53} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function positiveModulo: In scope SELECT positiveModulo([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT positiveModulo([], []);) 2025.10.23 23:31:39.340538 [ 6609 ] {aed0d33c-7abb-4f76-982b-e164fae3cf53} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function positiveModulo: In scope SELECT positiveModulo([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:39.387953 [ 3256 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:39.429224 [ 6609 ] {4904a521-27e0-4fd7-b312-2007d52fc8b1} executeQuery: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function positiveModulo: In scope SELECT positive_modulo([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT positive_modulo([], []);) 2025.10.23 23:31:39.443771 [ 6609 ] {4904a521-27e0-4fd7-b312-2007d52fc8b1} TCPHandler: Code: 43. DB::Exception: Illegal types Array(Nothing) and Array(Nothing) of arguments of function positiveModulo: In scope SELECT positive_modulo([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:39.564954 [ 6609 ] {c07fa48d-ba74-4c68-a619-429e8648537f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function pow: In scope SELECT pow([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT pow([], []);) 2025.10.23 23:31:39.566419 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:39.575845 [ 6609 ] {c07fa48d-ba74-4c68-a619-429e8648537f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function pow: In scope SELECT pow([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:39.582391 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:39.688425 [ 6609 ] {15a23f4d-6239-49d0-8aaa-b8ec2c388e05} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function pow: In scope SELECT power([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT power([], []);) 2025.10.23 23:31:39.695724 [ 6609 ] {15a23f4d-6239-49d0-8aaa-b8ec2c388e05} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function pow: In scope SELECT power([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:39.842445 [ 6609 ] {743d7f31-023d-4a16-b09f-6b0704a5beca} executeQuery: Code: 43. DB::Exception: The first argument type of function printf is Array(Nothing), but String type is expected: In scope SELECT printf([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT printf([], []);) 2025.10.23 23:31:39.847008 [ 6609 ] {743d7f31-023d-4a16-b09f-6b0704a5beca} TCPHandler: Code: 43. DB::Exception: The first argument type of function printf is Array(Nothing), but String type is expected: In scope SELECT printf([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:39.900773 [ 6609 ] {9aa7e161-b7ea-4d9c-9262-3e5c803004fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT proportionsZTest([], []);) 2025.10.23 23:31:39.907893 [ 6609 ] {9aa7e161-b7ea-4d9c-9262-3e5c803004fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function proportionsZTest doesn't match: passed 2, should be 6: In scope SELECT proportionsZTest([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:39.972437 [ 6609 ] {82024be4-70b4-4523-b04d-100d3daaf18d} executeQuery: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT protocol([], []);) 2025.10.23 23:31:39.976694 [ 6609 ] {82024be4-70b4-4523-b04d-100d3daaf18d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function protocol doesn't match: passed 2, should be 1: In scope SELECT protocol([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:39.997662 [ 3268 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:40.051207 [ 6609 ] {90b2ee61-94d0-4ccd-b37f-aacba4315801} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT punycodeDecode([], []);) 2025.10.23 23:31:40.056790 [ 6609 ] {90b2ee61-94d0-4ccd-b37f-aacba4315801} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeDecode doesn't match: passed 2, should be 1: In scope SELECT punycodeDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:40.160089 [ 6609 ] {10bc45ec-6a18-4f5e-925e-2c686c501178} executeQuery: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT punycodeEncode([], []);) 2025.10.23 23:31:40.170410 [ 6609 ] {10bc45ec-6a18-4f5e-925e-2c686c501178} TCPHandler: Code: 42. DB::Exception: Number of arguments for function punycodeEncode doesn't match: passed 2, should be 1: In scope SELECT punycodeEncode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:40.300133 [ 3275 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:40.301242 [ 6609 ] {082cbc58-d34c-44b6-867d-0efd90941bf4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantile([], []);) 2025.10.23 23:31:40.308002 [ 6609 ] {082cbc58-d34c-44b6-867d-0efd90941bf4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantile. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:40.390329 [ 3282 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:40.481804 [ 6609 ] {745255ab-d00c-4fce-9b44-f2b56a3566f4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileBFloat16([], []);) 2025.10.23 23:31:40.484421 [ 6609 ] {745255ab-d00c-4fce-9b44-f2b56a3566f4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:40.572026 [ 6609 ] {62556b5b-88d7-4ca4-9f21-93b0659a0aa4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileBFloat16Weighted([], []);) 2025.10.23 23:31:40.575606 [ 6609 ] {62556b5b-88d7-4ca4-9f21-93b0659a0aa4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:40.596597 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:40.646719 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:40.666786 [ 6609 ] {83d0c8ca-79f3-43cf-90c3-a9fd0511f813} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileDD([], []);) 2025.10.23 23:31:40.692582 [ 6609 ] {83d0c8ca-79f3-43cf-90c3-a9fd0511f813} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:40.796753 [ 6609 ] {69e90e13-e2f2-463d-9ff9-e3d907c406c2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileDeterministic([], []);) 2025.10.23 23:31:40.800983 [ 6609 ] {69e90e13-e2f2-463d-9ff9-e3d907c406c2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:40.847543 [ 6609 ] {0244402e-136a-4780-a650-fa6e7453dc9a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileExact([], []);) 2025.10.23 23:31:40.851030 [ 6609 ] {0244402e-136a-4780-a650-fa6e7453dc9a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:40.965532 [ 6609 ] {ee6a9edf-9465-4bd6-9e87-899e2dada540} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileExactExclusive([], []);) 2025.10.23 23:31:40.969077 [ 6609 ] {ee6a9edf-9465-4bd6-9e87-899e2dada540} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:40.999784 [ 3270 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:41.055117 [ 6609 ] {34381cdb-7874-4ebe-a679-86d18be43353} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileExactHigh([], []);) 2025.10.23 23:31:41.058977 [ 6609 ] {34381cdb-7874-4ebe-a679-86d18be43353} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.103561 [ 6609 ] {713faaa6-af03-49ec-8b1e-557eeb8b6dac} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileExactInclusive([], []);) 2025.10.23 23:31:41.108967 [ 6609 ] {713faaa6-af03-49ec-8b1e-557eeb8b6dac} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.149366 [ 6609 ] {50d36dfb-f02b-41fa-861c-b127e7175fe5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileExactLow([], []);) 2025.10.23 23:31:41.153515 [ 6609 ] {50d36dfb-f02b-41fa-861c-b127e7175fe5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.193059 [ 6609 ] {41f4386d-c669-4ddb-8361-3bcee1d0cca5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileExactWeighted([], []);) 2025.10.23 23:31:41.197617 [ 6609 ] {41f4386d-c669-4ddb-8361-3bcee1d0cca5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.302131 [ 2772 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:41.308811 [ 6609 ] {3947261f-e22f-4add-8049-c853f0cbf62a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileGK([], []);) 2025.10.23 23:31:41.319312 [ 6609 ] {3947261f-e22f-4add-8049-c853f0cbf62a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.392528 [ 2778 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:41.418163 [ 6609 ] {97b0b50a-f643-44bd-ad8e-fd42312339ef} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileInterpolatedWeighted([], []);) 2025.10.23 23:31:41.434554 [ 6609 ] {97b0b50a-f643-44bd-ad8e-fd42312339ef} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.553374 [ 6609 ] {ea9da2c9-3d2e-421b-9f67-eb9e7435d933} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileTDigest([], []);) 2025.10.23 23:31:41.560883 [ 6609 ] {ea9da2c9-3d2e-421b-9f67-eb9e7435d933} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.648232 [ 6609 ] {7cf20d17-9120-421b-814d-7497e764215a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileTDigestWeighted([], []);) 2025.10.23 23:31:41.652235 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:41.652634 [ 6609 ] {7cf20d17-9120-421b-814d-7497e764215a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.712162 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:41.770158 [ 6609 ] {9c96576c-1a41-491b-9d06-d5814724f4c2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileTiming([], []);) 2025.10.23 23:31:41.775347 [ 6609 ] {9c96576c-1a41-491b-9d06-d5814724f4c2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.872878 [ 6609 ] {2c92e8f9-5bff-4b9f-a0b0-0bd4d46fd038} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantileTimingWeighted([], []);) 2025.10.23 23:31:41.877763 [ 6609 ] {2c92e8f9-5bff-4b9f-a0b0-0bd4d46fd038} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantileTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.913328 [ 6609 ] {f3dd74c9-b640-4ee7-b5ff-630061a2179b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantiles([], []);) 2025.10.23 23:31:41.918161 [ 6609 ] {f3dd74c9-b640-4ee7-b5ff-630061a2179b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantiles. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:41.968349 [ 6609 ] {1d67acf7-d500-4926-b110-1214da92791a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesBFloat16([], []);) 2025.10.23 23:31:41.972431 [ 6609 ] {1d67acf7-d500-4926-b110-1214da92791a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.005529 [ 2792 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:42.014714 [ 6609 ] {6e08566c-d5a4-48bc-b18a-7e32ba8d1eac} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesBFloat16Weighted([], []);) 2025.10.23 23:31:42.019151 [ 6609 ] {6e08566c-d5a4-48bc-b18a-7e32ba8d1eac} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesBFloat16Weighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.075468 [ 3621 ] {16c8b13a-278b-4279-89ab-32a7cfacb79c} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:42.078355 [ 3621 ] {16c8b13a-278b-4279-89ab-32a7cfacb79c} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:42.088788 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (6 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:42.168375 [ 6609 ] {2d365594-cce9-4113-a5a7-d762b5422d9b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesDD([], []);) 2025.10.23 23:31:42.177315 [ 6609 ] {2d365594-cce9-4113-a5a7-d762b5422d9b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDD. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.224819 [ 6609 ] {18713bf6-7dee-4b32-8128-d8ce1181fb99} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesDeterministic([], []);) 2025.10.23 23:31:42.228849 [ 6609 ] {18713bf6-7dee-4b32-8128-d8ce1181fb99} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesDeterministic. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.304464 [ 2780 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:42.304698 [ 6609 ] {eeea34ab-38b6-4388-9151-a740569f1630} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesExact([], []);) 2025.10.23 23:31:42.309132 [ 6609 ] {eeea34ab-38b6-4388-9151-a740569f1630} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExact. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.394862 [ 2784 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:42.481886 [ 6609 ] {0febee2f-7374-415b-a147-94a65f76c8a7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesExactExclusive([], []);) 2025.10.23 23:31:42.487435 [ 6609 ] {0febee2f-7374-415b-a147-94a65f76c8a7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactExclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.658664 [ 6609 ] {f1bdd9e7-a784-4ab6-8b41-03e27ce79756} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesExactHigh([], []);) 2025.10.23 23:31:42.663351 [ 6609 ] {f1bdd9e7-a784-4ab6-8b41-03e27ce79756} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactHigh. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.763555 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:42.816886 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:42.819845 [ 6609 ] {a93bacf2-ec8a-4751-bf1b-45fa769dfc0c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesExactInclusive([], []);) 2025.10.23 23:31:42.822619 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:42.823931 [ 6609 ] {a93bacf2-ec8a-4751-bf1b-45fa769dfc0c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactInclusive. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.928689 [ 6609 ] {f8e37976-bdc7-419f-b7b5-af18e3640e69} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesExactLow([], []);) 2025.10.23 23:31:42.934936 [ 6609 ] {f8e37976-bdc7-419f-b7b5-af18e3640e69} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactLow. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:42.976609 [ 6609 ] {d03ade9e-68c9-44c7-a7b0-27c1d940d364} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesExactWeighted([], []);) 2025.10.23 23:31:42.980270 [ 6609 ] {d03ade9e-68c9-44c7-a7b0-27c1d940d364} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesExactWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:43.007689 [ 2793 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:43.021127 [ 6609 ] {b0bd9925-e8eb-40b9-91a7-579835abfded} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesGK([], []);) 2025.10.23 23:31:43.024637 [ 6609 ] {b0bd9925-e8eb-40b9-91a7-579835abfded} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesGK. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:43.092488 [ 6609 ] {940891be-b390-4cdb-84bb-557d32aab7b8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesInterpolatedWeighted([], []);) 2025.10.23 23:31:43.097278 [ 6609 ] {940891be-b390-4cdb-84bb-557d32aab7b8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesInterpolatedWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:43.146221 [ 6609 ] {aad35acc-f74f-49bd-879d-97674b8fd8e1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesTDigest([], []);) 2025.10.23 23:31:43.149786 [ 6609 ] {aad35acc-f74f-49bd-879d-97674b8fd8e1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigest. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:43.291391 [ 6609 ] {eeff2593-1fe2-469b-b8f6-a54ce1b96098} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesTDigestWeighted([], []);) 2025.10.23 23:31:43.295325 [ 6609 ] {eeff2593-1fe2-469b-b8f6-a54ce1b96098} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTDigestWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:43.306737 [ 2811 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:43.397503 [ 2819 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:43.558910 [ 6609 ] {293cdbe6-9e4b-42fb-8c57-8c3219d21be1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesTiming([], []);) 2025.10.23 23:31:43.562780 [ 6609 ] {293cdbe6-9e4b-42fb-8c57-8c3219d21be1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTiming. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:43.688738 [ 6609 ] {f7d36ef8-3fb7-4070-8f42-7b22539eed3a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT quantilesTimingWeighted([], []);) 2025.10.23 23:31:43.731375 [ 6609 ] {f7d36ef8-3fb7-4070-8f42-7b22539eed3a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument for aggregate function quantilesTimingWeighted. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:43.792817 [ 6609 ] {89e2dbfc-2527-47d5-9157-3a1d9b5d4de2} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT queryID([], []);) 2025.10.23 23:31:43.824362 [ 6609 ] {89e2dbfc-2527-47d5-9157-3a1d9b5d4de2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT queryID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:43.888610 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:43.894991 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:43.986652 [ 6609 ] {a91ff4c8-a36c-4a2b-9955-9c7c09ce5f61} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT queryString([], []);) 2025.10.23 23:31:43.997588 [ 6609 ] {a91ff4c8-a36c-4a2b-9955-9c7c09ce5f61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryString doesn't match: passed 2, should be 1: In scope SELECT queryString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:44.009757 [ 2829 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:44.155552 [ 6609 ] {1a9d223c-e175-479b-817d-288fcb7a2d42} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT queryStringAndFragment([], []);) 2025.10.23 23:31:44.158711 [ 6609 ] {1a9d223c-e175-479b-817d-288fcb7a2d42} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryStringAndFragment doesn't match: passed 2, should be 1: In scope SELECT queryStringAndFragment([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:44.208424 [ 6609 ] {4b8c8ced-6c4c-4695-a577-1de1472dd198} executeQuery: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT query_id([], []);) 2025.10.23 23:31:44.222238 [ 6609 ] {4b8c8ced-6c4c-4695-a577-1de1472dd198} TCPHandler: Code: 42. DB::Exception: Number of arguments for function queryID doesn't match: passed 2, should be 0: In scope SELECT query_id([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:44.308729 [ 2837 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:44.311215 [ 6609 ] {95abf931-f7a3-47d6-a98f-3442268d877b} executeQuery: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT radians([], []);) 2025.10.23 23:31:44.374581 [ 6609 ] {95abf931-f7a3-47d6-a98f-3442268d877b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function radians doesn't match: passed 2, should be 1: In scope SELECT radians([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:44.400096 [ 2828 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:44.415943 [ 6609 ] {5222a6b2-f95c-4e21-b8ac-be7f0b1cb5b2} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rand([], []);) 2025.10.23 23:31:44.420254 [ 6609 ] {5222a6b2-f95c-4e21-b8ac-be7f0b1cb5b2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:44.493563 [ 6609 ] {ee504f1b-aa3d-4207-b17f-884f42de5744} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rand32([], []);) 2025.10.23 23:31:44.507960 [ 6609 ] {ee504f1b-aa3d-4207-b17f-884f42de5744} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:44.661070 [ 6609 ] {d481bd42-c9f0-4e1f-9094-b0e207638b61} executeQuery: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rand64([], []);) 2025.10.23 23:31:44.679194 [ 6609 ] {d481bd42-c9f0-4e1f-9094-b0e207638b61} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rand64 doesn't match: passed 2, should be 0 or 1.: In scope SELECT rand64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:44.859377 [ 6609 ] {ccfcc946-88e8-4da5-996e-ddafe9527065} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randBernoulli, expected Float64 or integer: In scope SELECT randBernoulli([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randBernoulli([], []);) 2025.10.23 23:31:44.874042 [ 6609 ] {ccfcc946-88e8-4da5-996e-ddafe9527065} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randBernoulli, expected Float64 or integer: In scope SELECT randBernoulli([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:44.950753 [ 6609 ] {9211a82d-5642-40ed-a213-0ff11806c85b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randBinomial, expected Float64 or integer: In scope SELECT randBinomial([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randBinomial([], []);) 2025.10.23 23:31:44.954973 [ 6609 ] {9211a82d-5642-40ed-a213-0ff11806c85b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randBinomial, expected Float64 or integer: In scope SELECT randBinomial([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.010439 [ 6609 ] {b03ea3c3-773b-4fdd-af20-3afa044868eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randCanonical([], []);) 2025.10.23 23:31:45.016492 [ 2845 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:45.022020 [ 6609 ] {b03ea3c3-773b-4fdd-af20-3afa044868eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randCanonical doesn't match: passed 2, should be 0 or 1.: In scope SELECT randCanonical([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:45.029499 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:45.029688 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:45.128691 [ 6609 ] {a16368ee-2211-48b3-9aab-0a28d1e086dd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randChiSquared, expected Float64 or integer: In scope SELECT randChiSquared([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randChiSquared([], []);) 2025.10.23 23:31:45.133191 [ 6609 ] {a16368ee-2211-48b3-9aab-0a28d1e086dd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randChiSquared, expected Float64 or integer: In scope SELECT randChiSquared([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.192605 [ 6609 ] {592203c7-c100-4bdb-beaf-a5be441f2691} executeQuery: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randConstant([], []);) 2025.10.23 23:31:45.197871 [ 6609 ] {592203c7-c100-4bdb-beaf-a5be441f2691} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randConstant doesn't match: passed 2, should be 0 or 1.: In scope SELECT randConstant([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:45.242098 [ 6609 ] {c784469e-eaae-424c-8ede-f7e8f4004055} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randExponential, expected Float64 or integer: In scope SELECT randExponential([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randExponential([], []);) 2025.10.23 23:31:45.245843 [ 6609 ] {c784469e-eaae-424c-8ede-f7e8f4004055} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randExponential, expected Float64 or integer: In scope SELECT randExponential([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.287204 [ 6609 ] {89a03eff-b767-4455-a3b6-bb5a35ceb524} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randFisherF, expected Float64 or integer: In scope SELECT randFisherF([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randFisherF([], []);) 2025.10.23 23:31:45.291731 [ 6609 ] {89a03eff-b767-4455-a3b6-bb5a35ceb524} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randFisherF, expected Float64 or integer: In scope SELECT randFisherF([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.310724 [ 2860 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:45.333608 [ 6609 ] {70a8860c-2109-4369-bdb1-27c79c0d4805} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randLogNormal, expected Float64 or integer: In scope SELECT randLogNormal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randLogNormal([], []);) 2025.10.23 23:31:45.338280 [ 6609 ] {70a8860c-2109-4369-bdb1-27c79c0d4805} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randLogNormal, expected Float64 or integer: In scope SELECT randLogNormal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.400622 [ 6609 ] {93cc1d67-1cb8-476e-b4ca-3768e8d71b53} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randNegativeBinomial, expected Float64 or integer: In scope SELECT randNegativeBinomial([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randNegativeBinomial([], []);) 2025.10.23 23:31:45.402144 [ 2861 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:45.413799 [ 6609 ] {93cc1d67-1cb8-476e-b4ca-3768e8d71b53} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randNegativeBinomial, expected Float64 or integer: In scope SELECT randNegativeBinomial([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.464244 [ 6609 ] {d1d16ebe-345a-428d-9804-4cbfc945acfa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randNormal, expected Float64 or integer: In scope SELECT randNormal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randNormal([], []);) 2025.10.23 23:31:45.469243 [ 6609 ] {d1d16ebe-345a-428d-9804-4cbfc945acfa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randNormal, expected Float64 or integer: In scope SELECT randNormal([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.538909 [ 6609 ] {4c9c85b9-29a5-434d-979e-8bc82efc6f9f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randPoisson, expected Float64 or integer: In scope SELECT randPoisson([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randPoisson([], []);) 2025.10.23 23:31:45.542785 [ 6609 ] {4c9c85b9-29a5-434d-979e-8bc82efc6f9f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randPoisson, expected Float64 or integer: In scope SELECT randPoisson([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.594043 [ 6609 ] {b5a33b2d-4ab8-4354-8298-817fc527efff} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randStudentT, expected Float64 or integer: In scope SELECT randStudentT([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randStudentT([], []);) 2025.10.23 23:31:45.600031 [ 6609 ] {b5a33b2d-4ab8-4354-8298-817fc527efff} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randStudentT, expected Float64 or integer: In scope SELECT randStudentT([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.719012 [ 6609 ] {61e62a7c-7d49-4ac9-a883-0e826e17a7a5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randUniform, expected Float64 or integer: In scope SELECT randUniform([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randUniform([], []);) 2025.10.23 23:31:45.744585 [ 6609 ] {61e62a7c-7d49-4ac9-a883-0e826e17a7a5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function randUniform, expected Float64 or integer: In scope SELECT randUniform([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:45.860014 [ 6609 ] {a9fb09da-a138-4405-a6bc-6b6b0496022e} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randomFixedString([], []);) 2025.10.23 23:31:45.868867 [ 6609 ] {a9fb09da-a138-4405-a6bc-6b6b0496022e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomFixedString doesn't match: passed 2, should be 1: In scope SELECT randomFixedString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:46.002977 [ 6609 ] {fd03d410-d12c-4dd1-b24b-135932e61d85} executeQuery: Code: 43. DB::Exception: First argument of function randomPrintableASCII must have numeric type: In scope SELECT randomPrintableASCII([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randomPrintableASCII([], []);) 2025.10.23 23:31:46.016635 [ 6609 ] {fd03d410-d12c-4dd1-b24b-135932e61d85} TCPHandler: Code: 43. DB::Exception: First argument of function randomPrintableASCII must have numeric type: In scope SELECT randomPrintableASCII([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:46.018433 [ 2875 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:46.052617 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:46.115222 [ 6609 ] {a465b290-223f-4912-ac06-e130a6d0c453} executeQuery: Code: 43. DB::Exception: First argument of function randomString must have numeric type: In scope SELECT randomString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randomString([], []);) 2025.10.23 23:31:46.134712 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:46.138416 [ 6609 ] {a465b290-223f-4912-ac06-e130a6d0c453} TCPHandler: Code: 43. DB::Exception: First argument of function randomString must have numeric type: In scope SELECT randomString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:46.230235 [ 6609 ] {f956b18f-79ce-440d-8810-e5e47917294d} executeQuery: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT randomStringUTF8([], []);) 2025.10.23 23:31:46.237594 [ 6609 ] {f956b18f-79ce-440d-8810-e5e47917294d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function randomStringUTF8 doesn't match: passed 2, should be 1: In scope SELECT randomStringUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:46.277653 [ 6609 ] {f0c98bd2-beba-49e4-96e3-d29fe732ccf2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function range: In scope SELECT range([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT range([], []);) 2025.10.23 23:31:46.281198 [ 6609 ] {f0c98bd2-beba-49e4-96e3-d29fe732ccf2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function range: In scope SELECT range([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:46.312768 [ 2881 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:46.404460 [ 2882 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:46.487175 [ 6609 ] {e88ab985-34e7-44fe-a1d9-3f4c6e0ca51b} executeQuery: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rank([], []);) 2025.10.23 23:31:46.491002 [ 6609 ] {e88ab985-34e7-44fe-a1d9-3f4c6e0ca51b} TCPHandler: Code: 36. DB::Exception: The function 'rank' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:31:46.531876 [ 6609 ] {d69baf28-f930-4805-bbbf-b4b6f02bcb99} executeQuery: Code: 48. DB::Exception: Aggregate function rankCorr only supports numerical types. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rankCorr([], []);) 2025.10.23 23:31:46.538821 [ 6609 ] {d69baf28-f930-4805-bbbf-b4b6f02bcb99} TCPHandler: Code: 48. DB::Exception: Aggregate function rankCorr only supports numerical types. (NOT_IMPLEMENTED) 2025.10.23 23:31:46.582823 [ 6609 ] {d762937e-a89b-4255-a94e-816437a0ab87} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT readWKTLineString([], []);) 2025.10.23 23:31:46.587882 [ 6609 ] {d762937e-a89b-4255-a94e-816437a0ab87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTLineString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:46.630802 [ 6609 ] {f70f145a-e331-40e1-88de-6129ccad5294} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT readWKTMultiLineString([], []);) 2025.10.23 23:31:46.635266 [ 6609 ] {f70f145a-e331-40e1-88de-6129ccad5294} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiLineString doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiLineString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:46.719884 [ 6609 ] {d958a939-0252-4025-8277-054c6bc85765} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT readWKTMultiPolygon([], []);) 2025.10.23 23:31:46.726170 [ 6609 ] {d958a939-0252-4025-8277-054c6bc85765} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTMultiPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTMultiPolygon([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:46.850885 [ 6609 ] {17413880-c066-4e9b-8b92-471ad47ed220} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT readWKTPoint([], []);) 2025.10.23 23:31:46.861623 [ 6609 ] {17413880-c066-4e9b-8b92-471ad47ed220} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPoint doesn't match: passed 2, should be 1: In scope SELECT readWKTPoint([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:46.973762 [ 6609 ] {e502072e-5459-40bc-8a63-35a34120d347} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT readWKTPolygon([], []);) 2025.10.23 23:31:46.981481 [ 6609 ] {e502072e-5459-40bc-8a63-35a34120d347} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTPolygon doesn't match: passed 2, should be 1: In scope SELECT readWKTPolygon([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:47.022125 [ 2892 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:47.099526 [ 6609 ] {c6238b89-426f-4375-8923-e4ef821af608} executeQuery: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT readWKTRing([], []);) 2025.10.23 23:31:47.104092 [ 6609 ] {c6238b89-426f-4375-8923-e4ef821af608} TCPHandler: Code: 42. DB::Exception: Number of arguments for function readWKTRing doesn't match: passed 2, should be 1: In scope SELECT readWKTRing([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:47.152172 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:47.187098 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:47.226060 [ 6609 ] {eaca1f94-281a-4b47-aacd-69f48baacff6} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nothing): In scope SELECT regexpExtract([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regexpExtract([], []);) 2025.10.23 23:31:47.231407 [ 6609 ] {eaca1f94-281a-4b47-aacd-69f48baacff6} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'haystack' to function 'regexpExtract'. Expected: String, got: Array(Nothing): In scope SELECT regexpExtract([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.300550 [ 6609 ] {1e1446a4-be9b-4830-87cb-c6ac82d31b87} executeQuery: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regexpQuoteMeta([], []);) 2025.10.23 23:31:47.305489 [ 3621 ] {186efbea-dcc3-4d05-afaf-db1a55782d9f} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:47.306345 [ 6609 ] {1e1446a4-be9b-4830-87cb-c6ac82d31b87} TCPHandler: Code: 42. DB::Exception: Number of arguments for function regexpQuoteMeta doesn't match: passed 2, should be 1: In scope SELECT regexpQuoteMeta([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:47.309121 [ 3621 ] {186efbea-dcc3-4d05-afaf-db1a55782d9f} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:47.314713 [ 2898 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:47.319957 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (7 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:47.406573 [ 2900 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:47.418901 [ 6609 ] {4bae7576-aa51-4d23-b886-c3e7fb0d54fe} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionHierarchy (must be UInt32): In scope SELECT regionHierarchy([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionHierarchy([], []);) 2025.10.23 23:31:47.421320 [ 6609 ] {4bae7576-aa51-4d23-b886-c3e7fb0d54fe} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionHierarchy (must be UInt32): In scope SELECT regionHierarchy([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.461601 [ 6609 ] {8db4ae0f-de22-4e8e-b538-a41524efd882} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function regionIn (must be UInt32): In scope SELECT regionIn([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionIn([], []);) 2025.10.23 23:31:47.466292 [ 6609 ] {8db4ae0f-de22-4e8e-b538-a41524efd882} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function regionIn (must be UInt32): In scope SELECT regionIn([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.511735 [ 6609 ] {c585d5f6-d2b3-4456-ad5e-1a80577e1102} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToArea (must be UInt32): In scope SELECT regionToArea([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionToArea([], []);) 2025.10.23 23:31:47.517349 [ 6609 ] {c585d5f6-d2b3-4456-ad5e-1a80577e1102} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToArea (must be UInt32): In scope SELECT regionToArea([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.572197 [ 6609 ] {f5a28932-535f-4dff-a1c7-97fd7926ab95} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToCity (must be UInt32): In scope SELECT regionToCity([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionToCity([], []);) 2025.10.23 23:31:47.576492 [ 6609 ] {f5a28932-535f-4dff-a1c7-97fd7926ab95} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToCity (must be UInt32): In scope SELECT regionToCity([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.632227 [ 6609 ] {d6000923-9a89-4fb6-84f4-d04bf23a7ac3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToContinent (must be UInt32): In scope SELECT regionToContinent([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionToContinent([], []);) 2025.10.23 23:31:47.637233 [ 6609 ] {d6000923-9a89-4fb6-84f4-d04bf23a7ac3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToContinent (must be UInt32): In scope SELECT regionToContinent([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.681590 [ 6609 ] {a6c6eb78-6223-43f7-93ca-b56381842682} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToCountry (must be UInt32): In scope SELECT regionToCountry([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionToCountry([], []);) 2025.10.23 23:31:47.684997 [ 6609 ] {a6c6eb78-6223-43f7-93ca-b56381842682} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToCountry (must be UInt32): In scope SELECT regionToCountry([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.731254 [ 6609 ] {0241ddf2-6497-480e-9af5-b4e6ea1a60de} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToDistrict (must be UInt32): In scope SELECT regionToDistrict([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionToDistrict([], []);) 2025.10.23 23:31:47.736112 [ 6609 ] {0241ddf2-6497-480e-9af5-b4e6ea1a60de} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToDistrict (must be UInt32): In scope SELECT regionToDistrict([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.818593 [ 6609 ] {4c1f28d4-fb19-44f7-8cda-45ac97072dbd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function regionToName (must be UInt32): In scope SELECT regionToName([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionToName([], []);) 2025.10.23 23:31:47.824952 [ 6609 ] {4c1f28d4-fb19-44f7-8cda-45ac97072dbd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function regionToName (must be UInt32): In scope SELECT regionToName([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.915928 [ 6609 ] {a7fae71c-4f4b-47e0-84af-8bcee3aa3ca9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToPopulation (must be UInt32): In scope SELECT regionToPopulation([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionToPopulation([], []);) 2025.10.23 23:31:47.921317 [ 6609 ] {a7fae71c-4f4b-47e0-84af-8bcee3aa3ca9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToPopulation (must be UInt32): In scope SELECT regionToPopulation([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:47.933459 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:48.011303 [ 6609 ] {2f30f85b-9b7b-42e5-ba49-3ba282dc14b9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToTopContinent (must be UInt32): In scope SELECT regionToTopContinent([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT regionToTopContinent([], []);) 2025.10.23 23:31:48.015629 [ 6609 ] {2f30f85b-9b7b-42e5-ba49-3ba282dc14b9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function regionToTopContinent (must be UInt32): In scope SELECT regionToTopContinent([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:48.024149 [ 2907 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:48.129339 [ 6609 ] {020a4c41-8570-48c1-8310-c81b18a590cf} executeQuery: Code: 43. DB::Exception: Second argument to reinterpret must be a constant string describing type. Instead there is non-constant column of type Array(Nothing): In scope SELECT reinterpret([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpret([], []);) 2025.10.23 23:31:48.142521 [ 6609 ] {020a4c41-8570-48c1-8310-c81b18a590cf} TCPHandler: Code: 43. DB::Exception: Second argument to reinterpret must be a constant string describing type. Instead there is non-constant column of type Array(Nothing): In scope SELECT reinterpret([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:48.200209 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:48.218463 [ 6609 ] {87b9a91b-a64d-457a-a424-dd2a3ff4f027} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsDate([], []);) 2025.10.23 23:31:48.227688 [ 6609 ] {87b9a91b-a64d-457a-a424-dd2a3ff4f027} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDate doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:48.316966 [ 2914 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:48.324329 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:48.366006 [ 6609 ] {0fa817e4-551c-4854-8929-08874c91058d} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsDateTime([], []);) 2025.10.23 23:31:48.370335 [ 6609 ] {0fa817e4-551c-4854-8929-08874c91058d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsDateTime doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsDateTime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:48.408788 [ 2917 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:48.454492 [ 6609 ] {b7697fd8-d140-4fbe-b243-867ddc9d5a2f} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsFixedString([], []);) 2025.10.23 23:31:48.458584 [ 6609 ] {b7697fd8-d140-4fbe-b243-867ddc9d5a2f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFixedString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFixedString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:48.580591 [ 6609 ] {4cb552d7-62df-4c35-b205-21e0d9c3859b} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsFloat32([], []);) 2025.10.23 23:31:48.584786 [ 6609 ] {4cb552d7-62df-4c35-b205-21e0d9c3859b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:48.692482 [ 6609 ] {77d699e3-08dd-4d73-958a-b02ded7b31e6} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsFloat64([], []);) 2025.10.23 23:31:48.698614 [ 6609 ] {77d699e3-08dd-4d73-958a-b02ded7b31e6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsFloat64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsFloat64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:48.764625 [ 6609 ] {194ccac5-4401-4e9d-8274-66879a696640} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsInt128([], []);) 2025.10.23 23:31:48.769928 [ 6609 ] {194ccac5-4401-4e9d-8274-66879a696640} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt128([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:48.826650 [ 6609 ] {2ad71f03-317e-45a5-8863-a0d9c4a9f7fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsInt16([], []);) 2025.10.23 23:31:48.834626 [ 6609 ] {2ad71f03-317e-45a5-8863-a0d9c4a9f7fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:48.983033 [ 6609 ] {5c2b2902-03ee-4427-adb0-71ed92869479} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsInt256([], []);) 2025.10.23 23:31:48.991554 [ 6609 ] {5c2b2902-03ee-4427-adb0-71ed92869479} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:49.026485 [ 2926 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:49.115877 [ 6609 ] {dfab8e8f-bdb2-4f39-a563-82ccbbde35e3} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsInt32([], []);) 2025.10.23 23:31:49.131923 [ 6609 ] {dfab8e8f-bdb2-4f39-a563-82ccbbde35e3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:49.205594 [ 6609 ] {e5fae45e-86de-4664-a436-47682ce186de} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsInt64([], []);) 2025.10.23 23:31:49.217563 [ 6609 ] {e5fae45e-86de-4664-a436-47682ce186de} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:49.240379 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:49.319151 [ 2931 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:49.352778 [ 6609 ] {4fddc794-fe5d-4b02-9673-7956dba3f44e} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsInt8([], []);) 2025.10.23 23:31:49.368058 [ 6609 ] {4fddc794-fe5d-4b02-9673-7956dba3f44e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:49.378153 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:49.410915 [ 2932 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:49.446553 [ 6609 ] {8badc30a-8147-4a54-b6be-7b28a18239cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsString([], []);) 2025.10.23 23:31:49.458390 [ 6609 ] {8badc30a-8147-4a54-b6be-7b28a18239cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsString doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:49.517506 [ 6609 ] {658f6719-1b44-46ca-adf9-9c0aa0c42fe2} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsUInt128([], []);) 2025.10.23 23:31:49.522188 [ 6609 ] {658f6719-1b44-46ca-adf9-9c0aa0c42fe2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt128 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt128([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:49.649291 [ 6609 ] {ec19f3cc-a12c-45ec-89b2-c40ba2703c28} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsUInt16([], []);) 2025.10.23 23:31:49.652229 [ 6609 ] {ec19f3cc-a12c-45ec-89b2-c40ba2703c28} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt16 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:49.767165 [ 6609 ] {ac76d286-05c8-4dc6-9e79-496cc207fd30} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsUInt256([], []);) 2025.10.23 23:31:49.770957 [ 6609 ] {ac76d286-05c8-4dc6-9e79-496cc207fd30} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt256 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:49.816994 [ 6609 ] {88ca2dc3-a33d-41e1-9000-2bdfb01f484a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsUInt32([], []);) 2025.10.23 23:31:49.832889 [ 6609 ] {88ca2dc3-a33d-41e1-9000-2bdfb01f484a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt32 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:50.062962 [ 2943 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:50.065701 [ 6609 ] {5ab6da3c-1cd3-4bf8-919a-034d5d36e5b1} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsUInt64([], []);) 2025.10.23 23:31:50.068876 [ 6609 ] {5ab6da3c-1cd3-4bf8-919a-034d5d36e5b1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt64 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:50.164384 [ 6609 ] {cea35bd8-3bbf-46ed-b113-d744660ff4cf} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsUInt8([], []);) 2025.10.23 23:31:50.173591 [ 6609 ] {cea35bd8-3bbf-46ed-b113-d744660ff4cf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUInt8 doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:50.253782 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:50.265977 [ 6609 ] {0228dd1e-0da5-48e6-8a59-742e9005dcc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reinterpretAsUUID([], []);) 2025.10.23 23:31:50.273942 [ 6609 ] {0228dd1e-0da5-48e6-8a59-742e9005dcc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reinterpretAsUUID doesn't match: passed 2, should be 1: In scope SELECT reinterpretAsUUID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:50.324732 [ 2950 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:50.384280 [ 6609 ] {150c51ca-ff29-4861-b65b-0d30425121ff} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'repeat'. Expected: String, got: Array(Nothing): In scope SELECT repeat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT repeat([], []);) 2025.10.23 23:31:50.388461 [ 6609 ] {150c51ca-ff29-4861-b65b-0d30425121ff} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'repeat'. Expected: String, got: Array(Nothing): In scope SELECT repeat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:50.413266 [ 2946 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:50.430795 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:50.536569 [ 6609 ] {5bf7c0ef-6b31-4aba-b7d6-7c2af99edb95} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT replace([], []);) 2025.10.23 23:31:50.578805 [ 6609 ] {5bf7c0ef-6b31-4aba-b7d6-7c2af99edb95} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replace([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:50.640017 [ 6609 ] {f3c5229e-30d2-4589-958c-a33ddb84ba00} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT replaceAll([], []);) 2025.10.23 23:31:50.643265 [ 6609 ] {f3c5229e-30d2-4589-958c-a33ddb84ba00} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceAll doesn't match: passed 2, should be 3: In scope SELECT replaceAll([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:50.707848 [ 6609 ] {fe32ec16-4fdb-4b7f-bba2-9e901a035da9} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT replaceOne([], []);) 2025.10.23 23:31:50.713188 [ 6609 ] {fe32ec16-4fdb-4b7f-bba2-9e901a035da9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceOne doesn't match: passed 2, should be 3: In scope SELECT replaceOne([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:50.764437 [ 6609 ] {b91d2d3e-4121-40a7-9d7a-8b61d59e7929} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT replaceRegexpAll([], []);) 2025.10.23 23:31:50.769078 [ 6609 ] {b91d2d3e-4121-40a7-9d7a-8b61d59e7929} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpAll doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpAll([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:50.817211 [ 6609 ] {7db99e2c-a8f2-45f2-bee1-b38137a9acc0} executeQuery: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT replaceRegexpOne([], []);) 2025.10.23 23:31:50.828142 [ 6609 ] {7db99e2c-a8f2-45f2-bee1-b38137a9acc0} TCPHandler: Code: 42. DB::Exception: Number of arguments for function replaceRegexpOne doesn't match: passed 2, should be 3: In scope SELECT replaceRegexpOne([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:51.009030 [ 6609 ] {93de2bf6-e549-4589-a176-a7dfe4215061} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of aggregate function retention, must be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT retention([], []);) 2025.10.23 23:31:51.016333 [ 6609 ] {93de2bf6-e549-4589-a176-a7dfe4215061} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of aggregate function retention, must be UInt8. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:51.066952 [ 2962 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:51.135046 [ 6609 ] {6d19c0e1-aa1a-41be-af03-c07f8238e95a} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reverse([], []);) 2025.10.23 23:31:51.148429 [ 6609 ] {6d19c0e1-aa1a-41be-af03-c07f8238e95a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverse doesn't match: passed 2, should be 1: In scope SELECT reverse([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:51.258962 [ 6609 ] {1109d778-aa57-4512-8e43-8ce7c5c991d9} executeQuery: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT reverseUTF8([], []);) 2025.10.23 23:31:51.271754 [ 6609 ] {1109d778-aa57-4512-8e43-8ce7c5c991d9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function reverseUTF8 doesn't match: passed 2, should be 1: In scope SELECT reverseUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:51.284705 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:51.326856 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:51.412693 [ 6609 ] {4e8c494a-c30f-48ab-b7fb-16fd75d41525} executeQuery: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT revision([], []);) 2025.10.23 23:31:51.415445 [ 2974 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:51.417646 [ 6609 ] {4e8c494a-c30f-48ab-b7fb-16fd75d41525} TCPHandler: Code: 42. DB::Exception: Number of arguments for function revision doesn't match: passed 2, should be 0: In scope SELECT revision([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:51.450314 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:51.477505 [ 6609 ] {28b261e0-854b-425a-8f99-cff54da667b2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function right: In scope SELECT right([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT right([], []);) 2025.10.23 23:31:51.489871 [ 6609 ] {28b261e0-854b-425a-8f99-cff54da667b2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function right: In scope SELECT right([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:51.576171 [ 6609 ] {c55ae2c4-f3c6-45ec-9061-5e847c6e0546} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPad, should be string: In scope SELECT rightPad([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rightPad([], []);) 2025.10.23 23:31:51.580012 [ 6609 ] {c55ae2c4-f3c6-45ec-9061-5e847c6e0546} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPad, should be string: In scope SELECT rightPad([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:51.640913 [ 6609 ] {fd2cc75c-f32d-4b7b-a87e-40385c69eee9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPadUTF8, should be string: In scope SELECT rightPadUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rightPadUTF8([], []);) 2025.10.23 23:31:51.645572 [ 6609 ] {fd2cc75c-f32d-4b7b-a87e-40385c69eee9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPadUTF8, should be string: In scope SELECT rightPadUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:51.770910 [ 6609 ] {53f76b3f-aa5b-4250-88fc-2626b86ca05d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function rightUTF8: In scope SELECT rightUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rightUTF8([], []);) 2025.10.23 23:31:51.773281 [ 6609 ] {53f76b3f-aa5b-4250-88fc-2626b86ca05d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function rightUTF8: In scope SELECT rightUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:52.010917 [ 6609 ] {cccccc00-cb81-4274-b8af-f245815e0de4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'round'. Expected: A number to round, got: Array(Nothing): In scope SELECT round([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT round([], []);) 2025.10.23 23:31:52.013592 [ 6609 ] {cccccc00-cb81-4274-b8af-f245815e0de4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'round'. Expected: A number to round, got: Array(Nothing): In scope SELECT round([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:52.068936 [ 2987 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:52.108394 [ 6609 ] {e7fcf10b-ff51-48d9-93a7-d0cf29aa2139} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT roundAge([], []);) 2025.10.23 23:31:52.119044 [ 6609 ] {e7fcf10b-ff51-48d9-93a7-d0cf29aa2139} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundAge doesn't match: passed 2, should be 1: In scope SELECT roundAge([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:52.236152 [ 6609 ] {4bd95495-2b84-4024-83ae-c15042f43188} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'roundBankers'. Expected: A number to round, got: Array(Nothing): In scope SELECT roundBankers([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT roundBankers([], []);) 2025.10.23 23:31:52.248519 [ 6609 ] {4bd95495-2b84-4024-83ae-c15042f43188} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'roundBankers'. Expected: A number to round, got: Array(Nothing): In scope SELECT roundBankers([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:52.312876 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:52.328872 [ 2986 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:52.341995 [ 6609 ] {e0c9fbf0-44fc-462f-af5b-ec625420d7bf} executeQuery: Code: 43. DB::Exception: Unsupported type Array(Nothing) of first argument of function roundDown, must be numeric type.: In scope SELECT roundDown([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT roundDown([], []);) 2025.10.23 23:31:52.360012 [ 6609 ] {e0c9fbf0-44fc-462f-af5b-ec625420d7bf} TCPHandler: Code: 43. DB::Exception: Unsupported type Array(Nothing) of first argument of function roundDown, must be numeric type.: In scope SELECT roundDown([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:52.417184 [ 2995 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:52.524392 [ 3621 ] {ec091cb7-755d-421a-91ff-6356cc524c46} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:52.536806 [ 6609 ] {2e2b83f5-9bea-4d88-a81c-a76d92d3fb97} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT roundDuration([], []);) 2025.10.23 23:31:52.540588 [ 3621 ] {ec091cb7-755d-421a-91ff-6356cc524c46} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:52.549886 [ 6609 ] {2e2b83f5-9bea-4d88-a81c-a76d92d3fb97} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundDuration doesn't match: passed 2, should be 1: In scope SELECT roundDuration([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:52.553826 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:52.561358 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (8 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:52.660042 [ 6609 ] {57742336-eb82-411b-beb6-41d787e1a0cd} executeQuery: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT roundToExp2([], []);) 2025.10.23 23:31:52.663915 [ 6609 ] {57742336-eb82-411b-beb6-41d787e1a0cd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function roundToExp2 doesn't match: passed 2, should be 1: In scope SELECT roundToExp2([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:52.712359 [ 6609 ] {8bffc06e-12d1-47ca-aee5-7d7c882d5e30} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rowNumberInAllBlocks([], []);) 2025.10.23 23:31:52.718521 [ 6609 ] {8bffc06e-12d1-47ca-aee5-7d7c882d5e30} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInAllBlocks doesn't match: passed 2, should be 0: In scope SELECT rowNumberInAllBlocks([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:52.800579 [ 6609 ] {bd517feb-dcfb-4729-afc9-0750fe6ccdb5} executeQuery: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rowNumberInBlock([], []);) 2025.10.23 23:31:52.859560 [ 6609 ] {bd517feb-dcfb-4729-afc9-0750fe6ccdb5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function rowNumberInBlock doesn't match: passed 2, should be 0: In scope SELECT rowNumberInBlock([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:53.004946 [ 6609 ] {2dba909b-2673-4327-9896-8a6ed51b2a81} executeQuery: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT row_number([], []);) 2025.10.23 23:31:53.007757 [ 6609 ] {2dba909b-2673-4327-9896-8a6ed51b2a81} TCPHandler: Code: 36. DB::Exception: The function 'row_number' can only be used as a window function, not as an aggregate function: While executing AggregatingTransform. (BAD_ARGUMENTS) 2025.10.23 23:31:53.044139 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:53.044371 [ 4291 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:31:58: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=8, jobs=8). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:53.071552 [ 3005 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:53.102311 [ 6609 ] {8d1b32fd-4484-4611-a467-30da705221bf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPad, should be string: In scope SELECT rpad([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT rpad([], []);) 2025.10.23 23:31:53.120823 [ 6609 ] {8d1b32fd-4484-4611-a467-30da705221bf} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function rightPad, should be string: In scope SELECT rpad([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:53.271782 [ 6609 ] {86f52c0c-c200-4274-a824-6f7b7de23c59} executeQuery: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT runningAccumulate([], []);) 2025.10.23 23:31:53.285540 [ 6609 ] {86f52c0c-c200-4274-a824-6f7b7de23c59} TCPHandler: Code: 721. DB::Exception: Function runningAccumulate is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.10.23 23:31:53.335755 [ 3011 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:53.384280 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:53.395820 [ 6609 ] {714eaba3-521a-4e12-907f-29c62efb1669} executeQuery: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT runningConcurrency([], []);) 2025.10.23 23:31:53.405486 [ 6609 ] {714eaba3-521a-4e12-907f-29c62efb1669} TCPHandler: Code: 43. DB::Exception: Arguments for function runningConcurrency must be Date, DateTime, or DateTime64.: In scope SELECT runningConcurrency([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:53.427514 [ 3009 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:53.497668 [ 6609 ] {152c19e2-e448-4d76-8e40-ac230d3fc57e} executeQuery: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT runningDifference([], []);) 2025.10.23 23:31:53.518431 [ 6609 ] {152c19e2-e448-4d76-8e40-ac230d3fc57e} TCPHandler: Code: 721. DB::Exception: Function runningDifference is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.10.23 23:31:53.577244 [ 6609 ] {71ad2234-e2a4-4d93-ad67-0229de08bdf5} executeQuery: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT runningDifferenceStartingWithFirstValue([], []);) 2025.10.23 23:31:53.584935 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:53.588573 [ 6609 ] {71ad2234-e2a4-4d93-ad67-0229de08bdf5} TCPHandler: Code: 721. DB::Exception: Function runningDifferenceStartingWithFirstValue is deprecated since its usage is error-prone (see docs).Please use proper window function or set `allow_deprecated_error_prone_window_functions` setting to enable it. (DEPRECATED_FUNCTION) 2025.10.23 23:31:53.705575 [ 6609 ] {6f25fdbb-5225-4bc6-a42f-05757a03adfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2CapContains([], []);) 2025.10.23 23:31:53.710633 [ 6609 ] {6f25fdbb-5225-4bc6-a42f-05757a03adfd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapContains doesn't match: passed 2, should be 3: In scope SELECT s2CapContains([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:53.761269 [ 6609 ] {4b991860-bca4-411e-b462-451686255bd6} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2CapUnion([], []);) 2025.10.23 23:31:53.764904 [ 6609 ] {4b991860-bca4-411e-b462-451686255bd6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2CapUnion doesn't match: passed 2, should be 4: In scope SELECT s2CapUnion([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:53.805850 [ 6609 ] {5665d6d5-34ed-4abd-9e7e-de4bc15b9cfd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of function s2CellsIntersect. Must be UInt64: In scope SELECT s2CellsIntersect([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2CellsIntersect([], []);) 2025.10.23 23:31:53.809401 [ 6609 ] {5665d6d5-34ed-4abd-9e7e-de4bc15b9cfd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 0 of function s2CellsIntersect. Must be UInt64: In scope SELECT s2CellsIntersect([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:53.850004 [ 6609 ] {af1fc255-d36a-47cd-b2ef-e13024cfe884} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2GetNeighbors([], []);) 2025.10.23 23:31:53.854376 [ 6609 ] {af1fc255-d36a-47cd-b2ef-e13024cfe884} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2GetNeighbors doesn't match: passed 2, should be 1: In scope SELECT s2GetNeighbors([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:53.978893 [ 6609 ] {cc0da7a1-7862-4028-b617-4b2f6472cc13} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2RectAdd([], []);) 2025.10.23 23:31:53.982640 [ 6609 ] {cc0da7a1-7862-4028-b617-4b2f6472cc13} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectAdd doesn't match: passed 2, should be 3: In scope SELECT s2RectAdd([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:54.071461 [ 6609 ] {f29b94db-ecd7-408b-9d0c-a2a0d5651cfe} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2RectContains([], []);) 2025.10.23 23:31:54.073591 [ 3034 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:54.076717 [ 6609 ] {f29b94db-ecd7-408b-9d0c-a2a0d5651cfe} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectContains doesn't match: passed 2, should be 3: In scope SELECT s2RectContains([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:54.319458 [ 6609 ] {409340a3-68c9-4e7d-bc76-2dbb7a54b917} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2RectIntersection([], []);) 2025.10.23 23:31:54.321925 [ 6609 ] {409340a3-68c9-4e7d-bc76-2dbb7a54b917} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectIntersection doesn't match: passed 2, should be 4: In scope SELECT s2RectIntersection([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:54.337636 [ 3035 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:54.423644 [ 6609 ] {1dbfa8e4-a9e9-4b63-bd44-9ca98b582103} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2RectUnion([], []);) 2025.10.23 23:31:54.429816 [ 3029 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:54.436206 [ 6609 ] {1dbfa8e4-a9e9-4b63-bd44-9ca98b582103} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2RectUnion doesn't match: passed 2, should be 4: In scope SELECT s2RectUnion([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:54.438328 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:54.530488 [ 6609 ] {2f1f2fcd-8556-475c-8d93-77cb3a4c9af9} executeQuery: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT s2ToGeo([], []);) 2025.10.23 23:31:54.563657 [ 6609 ] {2f1f2fcd-8556-475c-8d93-77cb3a4c9af9} TCPHandler: Code: 42. DB::Exception: Number of arguments for function s2ToGeo doesn't match: passed 2, should be 1: In scope SELECT s2ToGeo([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:54.607567 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:54.616293 [ 6609 ] {3202cfd0-0c31-47a2-8ab6-06c022811233} executeQuery: Code: 43. DB::Exception: Function arrayDotProduct cannot process values of type Nothing: In scope SELECT scalarProduct([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT scalarProduct([], []);) 2025.10.23 23:31:54.631220 [ 6609 ] {3202cfd0-0c31-47a2-8ab6-06c022811233} TCPHandler: Code: 43. DB::Exception: Function arrayDotProduct cannot process values of type Nothing: In scope SELECT scalarProduct([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:54.708675 [ 6609 ] {33775a40-ff27-4474-ab9a-6625e2ffc3fa} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sequenceCount([], []);) 2025.10.23 23:31:54.712855 [ 6609 ] {33775a40-ff27-4474-ab9a-6625e2ffc3fa} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceCount requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:54.763140 [ 6609 ] {1ac17363-8693-4001-918b-ed4247cf14fe} executeQuery: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sequenceMatch([], []);) 2025.10.23 23:31:54.767390 [ 6609 ] {1ac17363-8693-4001-918b-ed4247cf14fe} TCPHandler: Code: 42. DB::Exception: Aggregate function sequenceMatch requires exactly one parameter. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:54.815494 [ 6609 ] {cb9dadae-40a6-46b1-90ca-875872eb3f76} executeQuery: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sequenceNextNode([], []);) 2025.10.23 23:31:54.819465 [ 6609 ] {cb9dadae-40a6-46b1-90ca-875872eb3f76} TCPHandler: Code: 63. DB::Exception: Aggregate function sequenceNextNode is experimental. Set `allow_experimental_funnel_functions` setting to enable it. (UNKNOWN_AGGREGATE_FUNCTION) 2025.10.23 23:31:54.867110 [ 6609 ] {69bfb185-3443-48fd-a6de-e39ac67d64a5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'period' to function 'seriesDecomposeSTL'. Expected: Unsigned Integer, got: Array(Nothing): In scope SELECT seriesDecomposeSTL([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT seriesDecomposeSTL([], []);) 2025.10.23 23:31:54.871644 [ 6609 ] {69bfb185-3443-48fd-a6de-e39ac67d64a5} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'period' to function 'seriesDecomposeSTL'. Expected: Unsigned Integer, got: Array(Nothing): In scope SELECT seriesDecomposeSTL([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:54.928308 [ 6609 ] {72169a78-c30e-41f0-94a7-91ca91941ff1} executeQuery: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 2.: In scope SELECT seriesOutliersDetectTukey([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT seriesOutliersDetectTukey([], []);) 2025.10.23 23:31:54.933603 [ 6609 ] {72169a78-c30e-41f0-94a7-91ca91941ff1} TCPHandler: Code: 42. DB::Exception: Function seriesOutliersDetectTukey needs either 1 or 4 arguments; passed 2.: In scope SELECT seriesOutliersDetectTukey([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:54.982453 [ 6609 ] {d1ce2c72-ba44-4586-bd39-60280388e90d} executeQuery: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT seriesPeriodDetectFFT([], []);) 2025.10.23 23:31:54.992350 [ 6609 ] {d1ce2c72-ba44-4586-bd39-60280388e90d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function seriesPeriodDetectFFT doesn't match: passed 2, should be 1: In scope SELECT seriesPeriodDetectFFT([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.040421 [ 6609 ] {0fa66ea0-4026-412a-85cf-0681c9e1265f} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT serverTimeZone([], []);) 2025.10.23 23:31:55.046820 [ 6609 ] {0fa66ea0-4026-412a-85cf-0681c9e1265f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimeZone([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.075599 [ 3044 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:55.167265 [ 6609 ] {bfa062ba-285f-4a92-83a9-f278ec07d4f1} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT serverTimezone([], []);) 2025.10.23 23:31:55.184912 [ 6609 ] {bfa062ba-285f-4a92-83a9-f278ec07d4f1} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverTimezone doesn't match: passed 2, should be 0: In scope SELECT serverTimezone([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.337213 [ 6609 ] {e328f3fd-923e-47ef-86ad-060a68a74cc3} executeQuery: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT serverUUID([], []);) 2025.10.23 23:31:55.339472 [ 3043 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:55.346506 [ 6609 ] {e328f3fd-923e-47ef-86ad-060a68a74cc3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function serverUUID doesn't match: passed 2, should be 0: In scope SELECT serverUUID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.432176 [ 3050 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:55.466370 [ 6609 ] {d2486234-d13e-4f5f-87d9-c83cfbe7d947} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT shardCount([], []);) 2025.10.23 23:31:55.483995 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:55.484549 [ 6609 ] {d2486234-d13e-4f5f-87d9-c83cfbe7d947} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardCount doesn't match: passed 2, should be 0: In scope SELECT shardCount([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.597666 [ 6609 ] {2f39041d-246f-4fa9-9f8e-9374a1016cc5} executeQuery: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT shardNum([], []);) 2025.10.23 23:31:55.602400 [ 6609 ] {2f39041d-246f-4fa9-9f8e-9374a1016cc5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function shardNum doesn't match: passed 2, should be 0: In scope SELECT shardNum([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.657871 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:55.665320 [ 6609 ] {40337235-998e-4dd8-85b5-dec23047943d} executeQuery: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT showCertificate([], []);) 2025.10.23 23:31:55.682485 [ 6609 ] {40337235-998e-4dd8-85b5-dec23047943d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function showCertificate doesn't match: passed 2, should be 0: In scope SELECT showCertificate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.789228 [ 6609 ] {5b174eaf-6f4e-4b70-a2a4-5fc773b94ee5} executeQuery: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sigmoid([], []);) 2025.10.23 23:31:55.793834 [ 6609 ] {5b174eaf-6f4e-4b70-a2a4-5fc773b94ee5} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sigmoid doesn't match: passed 2, should be 1: In scope SELECT sigmoid([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.922759 [ 6609 ] {fea3cbb0-00a3-41cc-91db-c19f0798d2df} executeQuery: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sign([], []);) 2025.10.23 23:31:55.927455 [ 6609 ] {fea3cbb0-00a3-41cc-91db-c19f0798d2df} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sign doesn't match: passed 2, should be 1: In scope SELECT sign([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:55.972933 [ 6609 ] {dccfb03c-22ca-490f-beee-21217aa0795e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractBool: In scope SELECT simpleJSONExtractBool([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT simpleJSONExtractBool([], []);) 2025.10.23 23:31:55.976083 [ 6609 ] {dccfb03c-22ca-490f-beee-21217aa0795e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractBool: In scope SELECT simpleJSONExtractBool([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:56.064951 [ 6609 ] {f9f0cbb9-da35-42d9-a7d4-2b84e0eef215} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractFloat: In scope SELECT simpleJSONExtractFloat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT simpleJSONExtractFloat([], []);) 2025.10.23 23:31:56.071531 [ 6609 ] {f9f0cbb9-da35-42d9-a7d4-2b84e0eef215} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractFloat: In scope SELECT simpleJSONExtractFloat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:56.078409 [ 3061 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:56.145519 [ 6609 ] {1c8a5c9e-7739-4b07-adfb-659f23e44bb1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractInt: In scope SELECT simpleJSONExtractInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT simpleJSONExtractInt([], []);) 2025.10.23 23:31:56.152897 [ 6609 ] {1c8a5c9e-7739-4b07-adfb-659f23e44bb1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractInt: In scope SELECT simpleJSONExtractInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:56.240969 [ 6609 ] {ae1559b3-f646-4a00-9d64-df7067d57e2f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractRaw: In scope SELECT simpleJSONExtractRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT simpleJSONExtractRaw([], []);) 2025.10.23 23:31:56.245322 [ 6609 ] {ae1559b3-f646-4a00-9d64-df7067d57e2f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractRaw: In scope SELECT simpleJSONExtractRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:56.341623 [ 6609 ] {b66f875f-3386-4cc5-9fdb-f9d91d109375} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractString: In scope SELECT simpleJSONExtractString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT simpleJSONExtractString([], []);) 2025.10.23 23:31:56.341726 [ 3063 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:56.345966 [ 6609 ] {b66f875f-3386-4cc5-9fdb-f9d91d109375} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractString: In scope SELECT simpleJSONExtractString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:56.434435 [ 3068 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:56.481252 [ 6609 ] {6091e58f-e1dd-4b8f-b8fc-1ef087d1a6fa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractUInt: In scope SELECT simpleJSONExtractUInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT simpleJSONExtractUInt([], []);) 2025.10.23 23:31:56.487988 [ 6609 ] {6091e58f-e1dd-4b8f-b8fc-1ef087d1a6fa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractUInt: In scope SELECT simpleJSONExtractUInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:56.527164 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:56.579001 [ 6609 ] {a0bd5383-dccc-4874-b8c1-a86a801d00fa} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONHas: In scope SELECT simpleJSONHas([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT simpleJSONHas([], []);) 2025.10.23 23:31:56.594403 [ 6609 ] {a0bd5383-dccc-4874-b8c1-a86a801d00fa} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONHas: In scope SELECT simpleJSONHas([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:56.669930 [ 6609 ] {765acaa8-7cf4-4730-a9c8-54a7fe09b0ce} executeQuery: Code: 43. DB::Exception: Illegal types (Array(Nothing), Array(Nothing)) of arguments of aggregate function simpleLinearRegression, must be Native Ints, Native UInts or Floats. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT simpleLinearRegression([], []);) 2025.10.23 23:31:56.675638 [ 6609 ] {765acaa8-7cf4-4730-a9c8-54a7fe09b0ce} TCPHandler: Code: 43. DB::Exception: Illegal types (Array(Nothing), Array(Nothing)) of arguments of aggregate function simpleLinearRegression, must be Native Ints, Native UInts or Floats. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:56.678779 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:56.771056 [ 6609 ] {02a6dc43-c45b-4eb8-a59a-4a5447b8eb5c} executeQuery: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sin([], []);) 2025.10.23 23:31:56.775058 [ 6609 ] {02a6dc43-c45b-4eb8-a59a-4a5447b8eb5c} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sin doesn't match: passed 2, should be 1: In scope SELECT sin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:56.824040 [ 6609 ] {a0b3e7e0-5ed7-456a-9aa6-a67b9b54dcde} executeQuery: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT singleValueOrNull([], []);) 2025.10.23 23:31:56.827947 [ 6609 ] {a0b3e7e0-5ed7-456a-9aa6-a67b9b54dcde} TCPHandler: Code: 42. DB::Exception: Aggregate function singleValueOrNull requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:56.887115 [ 6609 ] {2c7a0416-2cbb-4a9c-be61-f35ad2021428} executeQuery: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sinh([], []);) 2025.10.23 23:31:56.891561 [ 6609 ] {2c7a0416-2cbb-4a9c-be61-f35ad2021428} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sinh doesn't match: passed 2, should be 1: In scope SELECT sinh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:57.080863 [ 3077 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:57.097121 [ 6609 ] {533bbc12-20ab-439c-815b-ed174037e84c} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sipHash128Keyed([], []);) 2025.10.23 23:31:57.102594 [ 6609 ] {533bbc12-20ab-439c-815b-ed174037e84c} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128Keyed([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:57.297191 [ 6609 ] {5333d25e-f1e4-47cd-a12a-ab1d4e89168d} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sipHash128ReferenceKeyed([], []);) 2025.10.23 23:31:57.305324 [ 6609 ] {5333d25e-f1e4-47cd-a12a-ab1d4e89168d} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash128ReferenceKeyed([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:57.344182 [ 3081 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:57.437055 [ 3083 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:57.556676 [ 6609 ] {1f5e0b59-6e06-424c-9284-7612eb3435ac} executeQuery: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sipHash64Keyed([], []);) 2025.10.23 23:31:57.559499 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:57.563875 [ 6609 ] {1f5e0b59-6e06-424c-9284-7612eb3435ac} TCPHandler: Code: 36. DB::Exception: The key must be of type Tuple(UInt64, UInt64): In scope SELECT sipHash64Keyed([], []). (BAD_ARGUMENTS) 2025.10.23 23:31:57.673224 [ 6609 ] {2e6cfe46-b765-429a-8c5d-bc34db739b73} executeQuery: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT skewPop([], []);) 2025.10.23 23:31:57.677889 [ 6609 ] {2e6cfe46-b765-429a-8c5d-bc34db739b73} TCPHandler: Code: 42. DB::Exception: Aggregate function skewPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:57.705617 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:57.735258 [ 6609 ] {1754fa33-c1cd-43ff-b47f-bd5e57eb264c} executeQuery: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT skewSamp([], []);) 2025.10.23 23:31:57.742836 [ 6609 ] {1754fa33-c1cd-43ff-b47f-bd5e57eb264c} TCPHandler: Code: 42. DB::Exception: Aggregate function skewSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:57.842623 [ 6609 ] {86732003-5fdb-4bb8-b774-29dc0920b7e7} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sleep([], []);) 2025.10.23 23:31:57.905011 [ 3621 ] {f110bde7-cf50-4eb9-8ce2-cd94e42eaf79} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:31:57.907384 [ 3621 ] {f110bde7-cf50-4eb9-8ce2-cd94e42eaf79} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:57.914598 [ 6609 ] {86732003-5fdb-4bb8-b774-29dc0920b7e7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleep doesn't match: passed 2, should be 1: In scope SELECT sleep([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:57.985192 [ 6609 ] {15db639f-50ab-4d5b-bbf5-2986222f4f90} executeQuery: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sleepEachRow([], []);) 2025.10.23 23:31:57.990686 [ 6609 ] {15db639f-50ab-4d5b-bbf5-2986222f4f90} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sleepEachRow doesn't match: passed 2, should be 1: In scope SELECT sleepEachRow([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:58.016451 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (9 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:58.082690 [ 6609 ] {c86d310a-51d1-4615-8605-729f79205180} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT snowflakeIDToDateTime([], []);) 2025.10.23 23:31:58.082713 [ 3092 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:58.088294 [ 6609 ] {c86d310a-51d1-4615-8605-729f79205180} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:58.152740 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:58.177540 [ 6609 ] {ce2c53d8-afd9-4108-b477-349b8e10ea2e} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT snowflakeIDToDateTime64([], []);) 2025.10.23 23:31:58.184252 [ 6609 ] {ce2c53d8-afd9-4108-b477-349b8e10ea2e} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeIDToDateTime64'. Expected: UInt64, got: Array(Nothing): In scope SELECT snowflakeIDToDateTime64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:58.269671 [ 6609 ] {f36e28bd-9b37-4674-b2cb-d22e4a4ced77} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: Array(Nothing): In scope SELECT snowflakeToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT snowflakeToDateTime([], []);) 2025.10.23 23:31:58.274557 [ 6609 ] {f36e28bd-9b37-4674-b2cb-d22e4a4ced77} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime'. Expected: Int64, got: Array(Nothing): In scope SELECT snowflakeToDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:58.346380 [ 3097 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:58.376916 [ 6609 ] {cc9887f3-52ab-4bc6-9914-2da362db1234} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: Array(Nothing): In scope SELECT snowflakeToDateTime64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT snowflakeToDateTime64([], []);) 2025.10.23 23:31:58.400941 [ 6609 ] {cc9887f3-52ab-4bc6-9914-2da362db1234} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'value' to function 'snowflakeToDateTime64'. Expected: Int64, got: Array(Nothing): In scope SELECT snowflakeToDateTime64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:58.439332 [ 3103 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:58.545664 [ 6609 ] {98171b1e-037f-4f79-8268-c4c44dd00044} executeQuery: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT soundex([], []);) 2025.10.23 23:31:58.558031 [ 6609 ] {98171b1e-037f-4f79-8268-c4c44dd00044} TCPHandler: Code: 42. DB::Exception: Number of arguments for function soundex doesn't match: passed 2, should be 1: In scope SELECT soundex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:58.618638 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:58.657008 [ 6609 ] {b2cc691e-2fc4-4eb1-a274-b2771e7e623e} executeQuery: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT space([], []);) 2025.10.23 23:31:58.682878 [ 6609 ] {b2cc691e-2fc4-4eb1-a274-b2771e7e623e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function space doesn't match: passed 2, should be 1: In scope SELECT space([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:58.773975 [ 6609 ] {c1e617c5-a296-4627-9473-e5589af50127} executeQuery: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 0. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sparkBar([], []);) 2025.10.23 23:31:58.778804 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:58.782840 [ 6609 ] {c1e617c5-a296-4627-9473-e5589af50127} TCPHandler: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 0. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:58.875039 [ 6609 ] {ca1a7721-0c49-4652-9a09-593f72da8f4e} executeQuery: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 0. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sparkbar([], []);) 2025.10.23 23:31:58.879414 [ 6609 ] {ca1a7721-0c49-4652-9a09-593f72da8f4e} TCPHandler: Code: 42. DB::Exception: The number of params does not match for aggregate function 'sparkbar', expected 1 or 3, got 0. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:58.937297 [ 6609 ] {305edce2-6da0-45c1-8d2b-e05e7dce2f4c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Array(Nothing): In scope SELECT splitByAlpha([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT splitByAlpha([], []);) 2025.10.23 23:31:58.943227 [ 6609 ] {305edce2-6da0-45c1-8d2b-e05e7dce2f4c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'alphaTokens'. Expected: String, got: Array(Nothing): In scope SELECT splitByAlpha([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:58.999848 [ 6609 ] {68c8cba8-8e63-4f0b-a5c9-4a1682a167c4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: Array(Nothing): In scope SELECT splitByChar([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT splitByChar([], []);) 2025.10.23 23:31:59.005751 [ 6609 ] {68c8cba8-8e63-4f0b-a5c9-4a1682a167c4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByChar'. Expected: const String, got: Array(Nothing): In scope SELECT splitByChar([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:59.068282 [ 6609 ] {9fbe660d-5975-4b34-b0cb-32d30dd5013c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByNonAlpha'. Expected: String, got: Array(Nothing): In scope SELECT splitByNonAlpha([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT splitByNonAlpha([], []);) 2025.10.23 23:31:59.072254 [ 6609 ] {9fbe660d-5975-4b34-b0cb-32d30dd5013c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByNonAlpha'. Expected: String, got: Array(Nothing): In scope SELECT splitByNonAlpha([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:59.091678 [ 3113 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:59.115071 [ 6609 ] {c1871495-5d72-4433-b127-5255af645469} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByRegexp'. Expected: const String, got: Array(Nothing): In scope SELECT splitByRegexp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT splitByRegexp([], []);) 2025.10.23 23:31:59.119121 [ 6609 ] {c1871495-5d72-4433-b127-5255af645469} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByRegexp'. Expected: const String, got: Array(Nothing): In scope SELECT splitByRegexp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:59.178037 [ 6609 ] {8d095aa5-2cb2-4697-9532-b554f24f0361} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByString'. Expected: const String, got: Array(Nothing): In scope SELECT splitByString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT splitByString([], []);) 2025.10.23 23:31:59.184645 [ 6609 ] {8d095aa5-2cb2-4697-9532-b554f24f0361} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'separator' to function 'splitByString'. Expected: const String, got: Array(Nothing): In scope SELECT splitByString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:59.275803 [ 6609 ] {cd86bf5f-1ad0-41a5-87ae-cd8d1c3f79e4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByWhitespace'. Expected: String, got: Array(Nothing): In scope SELECT splitByWhitespace([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT splitByWhitespace([], []);) 2025.10.23 23:31:59.290642 [ 6609 ] {cd86bf5f-1ad0-41a5-87ae-cd8d1c3f79e4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 's' to function 'splitByWhitespace'. Expected: String, got: Array(Nothing): In scope SELECT splitByWhitespace([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:59.348867 [ 3119 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:59.424498 [ 6609 ] {dc863bd7-57e7-400a-b89f-c273bd3e72c2} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqid([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sqid([], []);) 2025.10.23 23:31:59.436795 [ 6609 ] {dc863bd7-57e7-400a-b89f-c273bd3e72c2} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqid([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:59.441443 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:31:59.570506 [ 6609 ] {6bc68894-dac3-408e-b23e-e9d827d97d8d} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sqidDecode([], []);) 2025.10.23 23:31:59.586089 [ 6609 ] {6bc68894-dac3-408e-b23e-e9d827d97d8d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqidDecode doesn't match: passed 2, should be 1: In scope SELECT sqidDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:31:59.763562 [ 6609 ] {9b11ae92-c316-4084-aa1c-b6fc3aa5bfd8} executeQuery: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqidEncode([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sqidEncode([], []);) 2025.10.23 23:31:59.773977 [ 6609 ] {9b11ae92-c316-4084-aa1c-b6fc3aa5bfd8} TCPHandler: Code: 43. DB::Exception: Argument 0 for function sqidEncode must have datatype UInt*, given type: Array(Nothing).: In scope SELECT sqidEncode([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:31:59.790345 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:59.886660 [ 6609 ] {3ad6e6f4-be0e-41e4-b563-26c77dc45739} executeQuery: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sqrt([], []);) 2025.10.23 23:31:59.899612 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:31:59.963030 [ 6609 ] {3ad6e6f4-be0e-41e4-b563-26c77dc45739} TCPHandler: Code: 42. DB::Exception: Number of arguments for function sqrt doesn't match: passed 2, should be 1: In scope SELECT sqrt([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:00.093947 [ 3133 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:00.165113 [ 6609 ] {0be024d8-5000-47c2-8539-78aa26f7c12f} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stddevPop([], []);) 2025.10.23 23:32:00.168869 [ 6609 ] {0be024d8-5000-47c2-8539-78aa26f7c12f} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:00.210766 [ 6609 ] {150526c6-6ef5-4dad-93f5-29855d988459} executeQuery: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stddevPopStable([], []);) 2025.10.23 23:32:00.216851 [ 6609 ] {150526c6-6ef5-4dad-93f5-29855d988459} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:00.261288 [ 6609 ] {0e5743d1-2122-4652-a0d9-baf509535ce7} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stddevSamp([], []);) 2025.10.23 23:32:00.270166 [ 6609 ] {0e5743d1-2122-4652-a0d9-baf509535ce7} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:00.320709 [ 6609 ] {3c78c916-a98d-4c26-9f1f-17fd81a22c80} executeQuery: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stddevSampStable([], []);) 2025.10.23 23:32:00.325827 [ 6609 ] {3c78c916-a98d-4c26-9f1f-17fd81a22c80} TCPHandler: Code: 42. DB::Exception: Aggregate function stddevSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:00.351019 [ 3141 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:00.424722 [ 6609 ] {1654d26f-544b-4525-95ba-cdf0afe16d2a} executeQuery: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stem([], []);) 2025.10.23 23:32:00.443396 [ 6609 ] {1654d26f-544b-4525-95ba-cdf0afe16d2a} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'stem' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:32:00.444357 [ 3144 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:00.543166 [ 6609 ] {1784eb55-2084-42d4-bac6-877428b79aed} executeQuery: Code: 43. DB::Exception: Argument 0 of type Array(Nothing) must be numeric for aggregate function stochasticLinearRegression. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stochasticLinearRegression([], []);) 2025.10.23 23:32:00.552592 [ 6609 ] {1784eb55-2084-42d4-bac6-877428b79aed} TCPHandler: Code: 43. DB::Exception: Argument 0 of type Array(Nothing) must be numeric for aggregate function stochasticLinearRegression. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:00.716560 [ 6609 ] {393ff133-47ad-4df0-b749-b0e4370cfeb3} executeQuery: Code: 43. DB::Exception: Argument 0 of type Array(Nothing) must be numeric for aggregate function stochasticLogisticRegression. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stochasticLogisticRegression([], []);) 2025.10.23 23:32:00.728777 [ 6609 ] {393ff133-47ad-4df0-b749-b0e4370cfeb3} TCPHandler: Code: 43. DB::Exception: Argument 0 of type Array(Nothing) must be numeric for aggregate function stochasticLogisticRegression. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:00.870901 [ 6609 ] {0ae9c905-b988-4655-8b0b-7a8e092f25c4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT str_to_date([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT str_to_date([], []);) 2025.10.23 23:32:00.882681 [ 6609 ] {0ae9c905-b988-4655-8b0b-7a8e092f25c4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'time' to function 'parseDateTimeOrNull'. Expected: String, got: Array(Nothing): In scope SELECT str_to_date([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:00.888536 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:00.964409 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:01.003823 [ 6609 ] {7c783f34-c42c-44d9-a6ae-ae81de625e8d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT str_to_map([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT str_to_map([], []);) 2025.10.23 23:32:01.009999 [ 6609 ] {7c783f34-c42c-44d9-a6ae-ae81de625e8d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument data_column. Must be String.: In scope SELECT str_to_map([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:01.076265 [ 6609 ] {2f300aac-3a3c-483e-adf7-14e263bb469e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function stringJaccardIndex: In scope SELECT stringJaccardIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stringJaccardIndex([], []);) 2025.10.23 23:32:01.079656 [ 6609 ] {2f300aac-3a3c-483e-adf7-14e263bb469e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function stringJaccardIndex: In scope SELECT stringJaccardIndex([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:01.096121 [ 3158 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:01.131517 [ 6609 ] {fd491d56-38e3-4746-8c56-a3e7e4204517} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function stringJaccardIndexUTF8: In scope SELECT stringJaccardIndexUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stringJaccardIndexUTF8([], []);) 2025.10.23 23:32:01.135398 [ 6609 ] {fd491d56-38e3-4746-8c56-a3e7e4204517} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function stringJaccardIndexUTF8: In scope SELECT stringJaccardIndexUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:01.173793 [ 6609 ] {04831653-5aa7-457e-8e17-e042e6fd4ffc} executeQuery: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT stringToH3([], []);) 2025.10.23 23:32:01.177537 [ 6609 ] {04831653-5aa7-457e-8e17-e042e6fd4ffc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function stringToH3 doesn't match: passed 2, should be 1: In scope SELECT stringToH3([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:01.219183 [ 6609 ] {3b9b94ac-81e7-43b0-a725-4ca2c094b822} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT structureToCapnProtoSchema([], []);) 2025.10.23 23:32:01.222999 [ 6609 ] {3b9b94ac-81e7-43b0-a725-4ca2c094b822} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function structureToCapnProtoSchema, expected constant string: In scope SELECT structureToCapnProtoSchema([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:01.270659 [ 6609 ] {a7220ef0-a8f6-474d-8a2d-15e9cee6cc5e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT structureToProtobufSchema([], []);) 2025.10.23 23:32:01.281169 [ 6609 ] {a7220ef0-a8f6-474d-8a2d-15e9cee6cc5e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function structureToProtobufSchema, expected constant string: In scope SELECT structureToProtobufSchema([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:01.355296 [ 3163 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:01.365856 [ 6609 ] {614f7cec-04b6-461b-abc9-42e386210a6a} executeQuery: Code: 36. DB::Exception: Aggregate function studentTTest only supports numerical types. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT studentTTest([], []);) 2025.10.23 23:32:01.369593 [ 6609 ] {614f7cec-04b6-461b-abc9-42e386210a6a} TCPHandler: Code: 36. DB::Exception: Aggregate function studentTTest only supports numerical types. (BAD_ARGUMENTS) 2025.10.23 23:32:01.446824 [ 3165 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:01.528852 [ 6609 ] {0e1198b3-2f7a-49ed-a364-aed18404fc57} executeQuery: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subBitmap([], []);) 2025.10.23 23:32:01.549641 [ 6609 ] {0e1198b3-2f7a-49ed-a364-aed18404fc57} TCPHandler: Code: 42. DB::Exception: Number of arguments for function subBitmap doesn't match: passed 2, should be 3: In scope SELECT subBitmap([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:01.694204 [ 6609 ] {6b0bc52f-133f-4aea-9c3b-28a7a8340eff} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function subDate. Should be a date, a date with time or a string: In scope SELECT subDate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subDate([], []);) 2025.10.23 23:32:01.704489 [ 6609 ] {6b0bc52f-133f-4aea-9c3b-28a7a8340eff} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function subDate. Should be a date, a date with time or a string: In scope SELECT subDate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:01.881252 [ 6609 ] {1387ad8c-fbd1-48bf-b866-3eea150f448f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT substr([], []);) 2025.10.23 23:32:01.933522 [ 6609 ] {1387ad8c-fbd1-48bf-b866-3eea150f448f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substr([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:01.996425 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:02.013267 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:02.099267 [ 3180 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:02.148391 [ 6609 ] {73e5fc56-1b53-410d-a40e-bc60bd4b96bd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substring([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT substring([], []);) 2025.10.23 23:32:02.153496 [ 6609 ] {73e5fc56-1b53-410d-a40e-bc60bd4b96bd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substring, expected String, FixedString or Enum: In scope SELECT substring([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:02.246663 [ 6609 ] {d127eff3-1aba-41ff-842b-a6c990b10855} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT substringIndex([], []);) 2025.10.23 23:32:02.261755 [ 6609 ] {d127eff3-1aba-41ff-842b-a6c990b10855} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndex doesn't match: passed 2, should be 3: In scope SELECT substringIndex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:02.357457 [ 3184 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:02.449028 [ 3181 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:02.451831 [ 6609 ] {af8e3834-d9af-4f8a-9a4d-b6bd354c675a} executeQuery: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT substringIndexUTF8([], []);) 2025.10.23 23:32:02.457434 [ 6609 ] {af8e3834-d9af-4f8a-9a4d-b6bd354c675a} TCPHandler: Code: 42. DB::Exception: Number of arguments for function substringIndexUTF8 doesn't match: passed 2, should be 3: In scope SELECT substringIndexUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:02.619334 [ 6609 ] {03dd9265-edaf-44a7-8736-99ebbc987103} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringUTF8, expected String: In scope SELECT substringUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT substringUTF8([], []);) 2025.10.23 23:32:02.622640 [ 6609 ] {03dd9265-edaf-44a7-8736-99ebbc987103} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function substringUTF8, expected String: In scope SELECT substringUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:02.743830 [ 6609 ] {ccdda611-d612-4880-b163-fad1da3f36ee} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractDays. Must be a date, a date with time or a String: In scope SELECT subtractDays([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractDays([], []);) 2025.10.23 23:32:02.754369 [ 6609 ] {ccdda611-d612-4880-b163-fad1da3f36ee} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractDays. Must be a date, a date with time or a String: In scope SELECT subtractDays([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:02.871366 [ 6609 ] {8ad73d5f-d712-49c8-a59f-11899618f238} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractHours. Must be a date, a date with time or a String: In scope SELECT subtractHours([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractHours([], []);) 2025.10.23 23:32:02.879640 [ 6609 ] {8ad73d5f-d712-49c8-a59f-11899618f238} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractHours. Must be a date, a date with time or a String: In scope SELECT subtractHours([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.021702 [ 6609 ] {20d147d0-ce68-4aeb-af72-b9ccc71d6d91} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractInterval, must be Tuple or Interval: In scope SELECT subtractInterval([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractInterval([], []);) 2025.10.23 23:32:03.024652 [ 6609 ] {20d147d0-ce68-4aeb-af72-b9ccc71d6d91} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractInterval, must be Tuple or Interval: In scope SELECT subtractInterval([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.034620 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:03.062339 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:03.089036 [ 6609 ] {f37ccc80-e0fc-4db5-bac3-162bb37f09d2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMicroseconds. Must be a date, a date with time or a String: In scope SELECT subtractMicroseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractMicroseconds([], []);) 2025.10.23 23:32:03.097401 [ 6609 ] {f37ccc80-e0fc-4db5-bac3-162bb37f09d2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMicroseconds. Must be a date, a date with time or a String: In scope SELECT subtractMicroseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.101979 [ 3194 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:03.136067 [ 3548 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:32:10: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:03.194911 [ 6609 ] {790f1c67-daea-4afc-8955-6b0daed2f805} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMilliseconds. Must be a date, a date with time or a String: In scope SELECT subtractMilliseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractMilliseconds([], []);) 2025.10.23 23:32:03.199482 [ 6609 ] {790f1c67-daea-4afc-8955-6b0daed2f805} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMilliseconds. Must be a date, a date with time or a String: In scope SELECT subtractMilliseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.218648 [ 3621 ] {36fc97e0-7512-4d06-aa5c-6a9d68faaffb} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:03.227365 [ 3621 ] {36fc97e0-7512-4d06-aa5c-6a9d68faaffb} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:03.228536 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:03.243803 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (10 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:03.277656 [ 6609 ] {75c60ce2-4e6d-4eee-b7ee-d8b8a9736857} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMinutes. Must be a date, a date with time or a String: In scope SELECT subtractMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractMinutes([], []);) 2025.10.23 23:32:03.286194 [ 6609 ] {75c60ce2-4e6d-4eee-b7ee-d8b8a9736857} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMinutes. Must be a date, a date with time or a String: In scope SELECT subtractMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.359692 [ 3193 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:03.368073 [ 6609 ] {6dfb39fc-da31-4d16-885a-f601063d7893} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMonths. Must be a date, a date with time or a String: In scope SELECT subtractMonths([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractMonths([], []);) 2025.10.23 23:32:03.374017 [ 6609 ] {6dfb39fc-da31-4d16-885a-f601063d7893} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractMonths. Must be a date, a date with time or a String: In scope SELECT subtractMonths([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.426587 [ 6609 ] {da2a2277-b2ad-4426-8861-37f1aa232b3e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractNanoseconds. Must be a date, a date with time or a String: In scope SELECT subtractNanoseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractNanoseconds([], []);) 2025.10.23 23:32:03.430133 [ 6609 ] {da2a2277-b2ad-4426-8861-37f1aa232b3e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractNanoseconds. Must be a date, a date with time or a String: In scope SELECT subtractNanoseconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.451647 [ 3200 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:03.571551 [ 6609 ] {f68e9a3c-df62-44bd-aaa9-c1e9171daf2a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractQuarters. Must be a date, a date with time or a String: In scope SELECT subtractQuarters([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractQuarters([], []);) 2025.10.23 23:32:03.575129 [ 6609 ] {f68e9a3c-df62-44bd-aaa9-c1e9171daf2a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractQuarters. Must be a date, a date with time or a String: In scope SELECT subtractQuarters([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.747120 [ 6609 ] {812459b4-9cc9-4136-acd7-21c1b1f16059} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractSeconds. Must be a date, a date with time or a String: In scope SELECT subtractSeconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractSeconds([], []);) 2025.10.23 23:32:03.757749 [ 6609 ] {812459b4-9cc9-4136-acd7-21c1b1f16059} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractSeconds. Must be a date, a date with time or a String: In scope SELECT subtractSeconds([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.868935 [ 6609 ] {114fae77-cb13-4ff4-bcca-d1bc2b4f9f35} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractTupleOfIntervals. Should be a date or a date with time: In scope SELECT subtractTupleOfIntervals([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractTupleOfIntervals([], []);) 2025.10.23 23:32:03.874306 [ 6609 ] {114fae77-cb13-4ff4-bcca-d1bc2b4f9f35} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractTupleOfIntervals. Should be a date or a date with time: In scope SELECT subtractTupleOfIntervals([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:03.972478 [ 6609 ] {1c2f6be4-9fc7-4bc0-a556-b747d58acf62} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractWeeks. Must be a date, a date with time or a String: In scope SELECT subtractWeeks([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractWeeks([], []);) 2025.10.23 23:32:03.993258 [ 6609 ] {1c2f6be4-9fc7-4bc0-a556-b747d58acf62} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractWeeks. Must be a date, a date with time or a String: In scope SELECT subtractWeeks([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:04.061111 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:04.074143 [ 6609 ] {c0e0d88a-902b-4d43-972c-be33f9f7f0fc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractYears. Must be a date, a date with time or a String: In scope SELECT subtractYears([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT subtractYears([], []);) 2025.10.23 23:32:04.080243 [ 6609 ] {c0e0d88a-902b-4d43-972c-be33f9f7f0fc} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function subtractYears. Must be a date, a date with time or a String: In scope SELECT subtractYears([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:04.112911 [ 3212 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:04.116840 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:04.172909 [ 6609 ] {ae956647-5f86-4183-97c4-2792852c3246} executeQuery: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sum([], []);) 2025.10.23 23:32:04.178671 [ 6609 ] {ae956647-5f86-4183-97c4-2792852c3246} TCPHandler: Code: 42. DB::Exception: Aggregate function sum requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:04.265407 [ 6609 ] {c87c7960-da72-4f1b-bbca-97818b6724f2} executeQuery: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sumCount([], []);) 2025.10.23 23:32:04.271843 [ 6609 ] {c87c7960-da72-4f1b-bbca-97818b6724f2} TCPHandler: Code: 42. DB::Exception: Aggregate function sumCount requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:04.327038 [ 6609 ] {d394eb21-95ed-464a-9cab-14f86476cfee} executeQuery: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sumKahan([], []);) 2025.10.23 23:32:04.333333 [ 6609 ] {d394eb21-95ed-464a-9cab-14f86476cfee} TCPHandler: Code: 42. DB::Exception: Aggregate function sumKahan requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:04.361807 [ 3221 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:04.412081 [ 6609 ] {1787cc46-0e2c-4c92-89b8-3dd03196a00c} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sumMapFiltered([], []);) 2025.10.23 23:32:04.417824 [ 6609 ] {1787cc46-0e2c-4c92-89b8-3dd03196a00c} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:04.454138 [ 3223 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:04.485421 [ 6609 ] {d534b44d-a71f-4cd1-ab72-16aea1bc80af} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sumMapFilteredWithOverflow([], []);) 2025.10.23 23:32:04.490606 [ 6609 ] {d534b44d-a71f-4cd1-ab72-16aea1bc80af} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:04.657236 [ 6609 ] {687f794e-7980-4277-a5bd-36875842f8c2} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sumMapWithOverflow([], []);) 2025.10.23 23:32:04.664643 [ 6609 ] {687f794e-7980-4277-a5bd-36875842f8c2} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:04.804264 [ 6609 ] {3ba5985b-92f4-4149-badf-f87d2a9eafc8} executeQuery: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sumMappedArrays([], []);) 2025.10.23 23:32:04.808877 [ 6609 ] {3ba5985b-92f4-4149-badf-f87d2a9eafc8} TCPHandler: Code: 43. DB::Exception: Values for -Map cannot be summed, passed type Nothing. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:04.952780 [ 6609 ] {ccc805f6-232a-448e-9237-c317a9b6b179} executeQuery: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT sumWithOverflow([], []);) 2025.10.23 23:32:04.971904 [ 6609 ] {ccc805f6-232a-448e-9237-c317a9b6b179} TCPHandler: Code: 42. DB::Exception: Aggregate function sumWithOverflow requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:05.085507 [ 6609 ] {01d38a4d-5b36-4306-9257-621a9c13472d} executeQuery: Code: 43. DB::Exception: Second argument should be String: In scope SELECT svg([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT svg([], []);) 2025.10.23 23:32:05.093678 [ 6609 ] {01d38a4d-5b36-4306-9257-621a9c13472d} TCPHandler: Code: 43. DB::Exception: Second argument should be String: In scope SELECT svg([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:05.098345 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:05.115135 [ 3235 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:05.195203 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:05.219372 [ 6609 ] {ce185e3b-a2f2-4b3c-9fb1-9ed290990eda} executeQuery: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT synonyms([], []);) 2025.10.23 23:32:05.227854 [ 6609 ] {ce185e3b-a2f2-4b3c-9fb1-9ed290990eda} TCPHandler: Code: 344. DB::Exception: Natural language processing function 'synonyms' is experimental. Set `allow_experimental_nlp_functions` setting to enable it. (SUPPORT_IS_DISABLED) 2025.10.23 23:32:05.311754 [ 6609 ] {207c3779-d27a-43b4-a203-c050b8eb67fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tan([], []);) 2025.10.23 23:32:05.325256 [ 6609 ] {207c3779-d27a-43b4-a203-c050b8eb67fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tan doesn't match: passed 2, should be 1: In scope SELECT tan([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:05.364070 [ 3237 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:05.436957 [ 6609 ] {288d5dc5-d4c2-48ec-81a6-9545bf1b442f} executeQuery: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tanh([], []);) 2025.10.23 23:32:05.442435 [ 6609 ] {288d5dc5-d4c2-48ec-81a6-9545bf1b442f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tanh doesn't match: passed 2, should be 1: In scope SELECT tanh([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:05.456313 [ 3249 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:05.499962 [ 6609 ] {54666a61-c569-454a-a0d6-56fc1fe9227e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tcpPort([], []);) 2025.10.23 23:32:05.512685 [ 6609 ] {54666a61-c569-454a-a0d6-56fc1fe9227e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tcpPort doesn't match: passed 2, should be 0: In scope SELECT tcpPort([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:05.558809 [ 6609 ] {22a42d63-113d-458f-8c70-47d74e6f04ae} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt64: In scope SELECT test_function([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT test_function([], []);) 2025.10.23 23:32:05.563080 [ 6609 ] {22a42d63-113d-458f-8c70-47d74e6f04ae} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toUInt64: In scope SELECT test_function([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:05.614411 [ 6609 ] {d10a1184-7a90-46d1-88b0-867dfa4b2cb8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tgamma([], []);) 2025.10.23 23:32:05.618634 [ 6609 ] {d10a1184-7a90-46d1-88b0-867dfa4b2cb8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tgamma doesn't match: passed 2, should be 1: In scope SELECT tgamma([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:05.685540 [ 6609 ] {67a90350-035b-432f-9298-9dfde30a46c6} 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.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT theilsU([], []);) 2025.10.23 23:32:05.688689 [ 6609 ] {67a90350-035b-432f-9298-9dfde30a46c6} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) 2025.10.23 23:32:05.966202 [ 6609 ] {f29fec0d-4994-4ca1-bd7c-4ba7772d9b32} executeQuery: Code: 43. DB::Exception: First argument of function throwIf must be a number (passed: Array(Nothing)): In scope SELECT throwIf([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT throwIf([], []);) 2025.10.23 23:32:06.000919 [ 6609 ] {f29fec0d-4994-4ca1-bd7c-4ba7772d9b32} TCPHandler: Code: 43. DB::Exception: First argument of function throwIf must be a number (passed: Array(Nothing)): In scope SELECT throwIf([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:06.103231 [ 6609 ] {0f4edc0f-9c33-4f38-967b-bd7182f738a8} executeQuery: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tid([], []);) 2025.10.23 23:32:06.107430 [ 6609 ] {0f4edc0f-9c33-4f38-967b-bd7182f738a8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tid doesn't match: passed 2, should be 0: In scope SELECT tid([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:06.118242 [ 3255 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:06.179456 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:06.187710 [ 6609 ] {94cd4928-5dbf-4cdb-a3ea-1e0819f26935} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'first_datetime' to function 'timeDiff'. Expected: Date[32] or DateTime[64], got: Array(Nothing): In scope SELECT timeDiff([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timeDiff([], []);) 2025.10.23 23:32:06.193608 [ 6609 ] {94cd4928-5dbf-4cdb-a3ea-1e0819f26935} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'first_datetime' to function 'timeDiff'. Expected: Date[32] or DateTime[64], got: Array(Nothing): In scope SELECT timeDiff([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:06.223010 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:06.323413 [ 6609 ] {f8717926-99ff-4a44-a783-50ec02bf36d1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timeSlot. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeSlot([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timeSlot([], []);) 2025.10.23 23:32:06.328939 [ 6609 ] {f8717926-99ff-4a44-a783-50ec02bf36d1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timeSlot. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeSlot([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:06.366320 [ 3260 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:06.458473 [ 3261 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:06.502735 [ 6609 ] {384add3f-a42e-4cd8-a17b-95139a4e7645} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function timeSlots. Must be DateTime or DateTime64.: In scope SELECT timeSlots([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timeSlots([], []);) 2025.10.23 23:32:06.512095 [ 6609 ] {384add3f-a42e-4cd8-a17b-95139a4e7645} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function timeSlots. Must be DateTime or DateTime64.: In scope SELECT timeSlots([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:06.563917 [ 6609 ] {815bb796-7b15-48ca-8f31-c0cbcaaa2ade} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timeZone([], []);) 2025.10.23 23:32:06.568929 [ 6609 ] {815bb796-7b15-48ca-8f31-c0cbcaaa2ade} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timeZone([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:06.621352 [ 6609 ] {d6a0c1fc-7d8d-4c03-b6bb-92befa20e268} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timeZoneOf([], []);) 2025.10.23 23:32:06.625783 [ 6609 ] {d6a0c1fc-7d8d-4c03-b6bb-92befa20e268} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timeZoneOf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:06.687152 [ 6609 ] {88b7cf4d-9752-438a-af22-7d50ce97c82c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeZoneOffset([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timeZoneOffset([], []);) 2025.10.23 23:32:06.692625 [ 6609 ] {88b7cf4d-9752-438a-af22-7d50ce97c82c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timeZoneOffset([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:06.748619 [ 6609 ] {ebb79216-c14a-414f-8c90-eb9bb1aeeb78} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT timestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timestamp([], []);) 2025.10.23 23:32:06.752776 [ 6609 ] {ebb79216-c14a-414f-8c90-eb9bb1aeeb78} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'timestamp' to function 'timestamp'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT timestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:06.819788 [ 6609 ] {55d0dd7b-bcab-497d-80cd-41a3796c28d7} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timestampDiff([], []);) 2025.10.23 23:32:06.827598 [ 6609 ] {55d0dd7b-bcab-497d-80cd-41a3796c28d7} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:06.970703 [ 6609 ] {452c276f-2622-4489-81d4-5ee846990082} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timestamp_diff([], []);) 2025.10.23 23:32:06.984674 [ 6609 ] {452c276f-2622-4489-81d4-5ee846990082} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'dateDiff'. Expected 3 mandatory arguments and 1 optional argument, got 2 arguments: In scope SELECT dateDiff([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:07.087271 [ 6609 ] {88b107fe-8f74-42da-b71e-601d61474179} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timezone([], []);) 2025.10.23 23:32:07.095631 [ 6609 ] {88b107fe-8f74-42da-b71e-601d61474179} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezone doesn't match: passed 2, should be 0: In scope SELECT timezone([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:07.120432 [ 3275 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:07.200247 [ 6609 ] {c46d9b4d-af11-4ff0-a0a6-ed21e957f580} executeQuery: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timezoneOf([], []);) 2025.10.23 23:32:07.202686 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:07.203442 [ 6609 ] {c46d9b4d-af11-4ff0-a0a6-ed21e957f580} TCPHandler: Code: 42. DB::Exception: Number of arguments for function timezoneOf doesn't match: passed 2, should be 1: In scope SELECT timezoneOf([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:07.243983 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:07.273406 [ 6609 ] {9f7a2cdb-d0bc-4985-83a4-15741d720886} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timezoneOffset([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT timezoneOffset([], []);) 2025.10.23 23:32:07.294003 [ 6609 ] {9f7a2cdb-d0bc-4985-83a4-15741d720886} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function timezoneOffset. Should be Date, Date32, DateTime or DateTime64: In scope SELECT timezoneOffset([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:07.368610 [ 3279 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:07.393988 [ 6609 ] {4d4ac4c1-8dd2-4ebc-806d-1535d38527c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toBool([], []);) 2025.10.23 23:32:07.404243 [ 6609 ] {4d4ac4c1-8dd2-4ebc-806d-1535d38527c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toBool doesn't match: passed 2, should be 1: In scope SELECT toBool([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:07.448410 [ 6609 ] {87d804b4-d9bc-4649-ae3d-095228231d51} executeQuery: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toColumnTypeName([], []);) 2025.10.23 23:32:07.452980 [ 6609 ] {87d804b4-d9bc-4649-ae3d-095228231d51} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toColumnTypeName doesn't match: passed 2, should be 1: In scope SELECT toColumnTypeName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:07.461332 [ 3280 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:07.597527 [ 6609 ] {07cc3bac-054d-49ca-b778-1e616daa1e6c} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDate'. Expected: String, got: Array(Nothing): In scope SELECT toDate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDate([], []);) 2025.10.23 23:32:07.609512 [ 6609 ] {07cc3bac-054d-49ca-b778-1e616daa1e6c} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDate'. Expected: String, got: Array(Nothing): In scope SELECT toDate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:07.656389 [ 6609 ] {591559d0-7545-42a4-8aa9-c48b7decf1cd} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDate32'. Expected: String, got: Array(Nothing): In scope SELECT toDate32([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDate32([], []);) 2025.10.23 23:32:07.670281 [ 6609 ] {591559d0-7545-42a4-8aa9-c48b7decf1cd} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDate32'. Expected: String, got: Array(Nothing): In scope SELECT toDate32([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:07.825025 [ 6609 ] {c2ebe4e9-78ef-4d2e-94de-99ed7446a15a} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Array(Nothing): In scope SELECT toDate32OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDate32OrDefault([], []);) 2025.10.23 23:32:07.840904 [ 6609 ] {c2ebe4e9-78ef-4d2e-94de-99ed7446a15a} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date32. Actual Array(Nothing): In scope SELECT toDate32OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:07.969543 [ 6609 ] {35af0db9-aa7f-491e-8f57-5d91a27eaff2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDate32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDate32OrNull([], []);) 2025.10.23 23:32:07.978490 [ 6609 ] {35af0db9-aa7f-491e-8f57-5d91a27eaff2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDate32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.067953 [ 6609 ] {b4988315-58b0-42f0-b232-12a6a48533c8} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDate32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDate32OrZero([], []);) 2025.10.23 23:32:08.073162 [ 6609 ] {b4988315-58b0-42f0-b232-12a6a48533c8} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDate32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDate32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.122570 [ 2785 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:08.212118 [ 6609 ] {e2829cab-46f6-43de-9b13-6e346123b0ce} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Array(Nothing): In scope SELECT toDateOrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateOrDefault([], []);) 2025.10.23 23:32:08.217305 [ 6609 ] {e2829cab-46f6-43de-9b13-6e346123b0ce} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Date. Actual Array(Nothing): In scope SELECT toDateOrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:08.244622 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:08.310788 [ 6609 ] {d0830bd7-af95-49a2-9d65-4402e50fd9b3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateOrNull([], []);) 2025.10.23 23:32:08.321466 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:08.322295 [ 6609 ] {d0830bd7-af95-49a2-9d65-4402e50fd9b3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.339689 [ 4147 ] {a7b3b76d-f16a-45e6-89b7-2d64aab2f2f2} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59230) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:08.343489 [ 4147 ] {a7b3b76d-f16a-45e6-89b7-2d64aab2f2f2} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:08.347084 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:08.370651 [ 2804 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:08.415927 [ 6609 ] {fad797a7-7a47-41d3-898a-e9b754a8cddd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateOrZero([], []);) 2025.10.23 23:32:08.423638 [ 6609 ] {fad797a7-7a47-41d3-898a-e9b754a8cddd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.463493 [ 2777 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:08.481660 [ 3621 ] {71b423f1-98d1-40fd-9601-aa48faee14b0} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:08.486950 [ 3621 ] {71b423f1-98d1-40fd-9601-aa48faee14b0} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:08.496640 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (11 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:08.597694 [ 6609 ] {023906d6-b15a-4fbc-a62e-cddf4c5646e4} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTime'. Expected: String, got: Array(Nothing): In scope SELECT toDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTime([], []);) 2025.10.23 23:32:08.602207 [ 6609 ] {023906d6-b15a-4fbc-a62e-cddf4c5646e4} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTime'. Expected: String, got: Array(Nothing): In scope SELECT toDateTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.649417 [ 6609 ] {6a8a817c-71ee-4b95-82fa-73ff19264fad} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTime32'. Expected: String, got: Array(Nothing): In scope SELECT toDateTime32([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTime32([], []);) 2025.10.23 23:32:08.652852 [ 6609 ] {6a8a817c-71ee-4b95-82fa-73ff19264fad} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTime32'. Expected: String, got: Array(Nothing): In scope SELECT toDateTime32([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.695020 [ 6609 ] {f6c76029-d40d-4f0b-982d-e1d588bf0d03} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTime64([], []);) 2025.10.23 23:32:08.698991 [ 6609 ] {f6c76029-d40d-4f0b-982d-e1d588bf0d03} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.762907 [ 6609 ] {3bbf5837-d633-4c1e-99e6-58b3c71931ef} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime64OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTime64OrDefault([], []);) 2025.10.23 23:32:08.767531 [ 6609 ] {3bbf5837-d633-4c1e-99e6-58b3c71931ef} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDateTime64OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDateTime64OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.871511 [ 6609 ] {e2828d96-e685-4bda-a230-7c950f63157a} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTime64OrNull([], []);) 2025.10.23 23:32:08.887506 [ 6609 ] {e2828d96-e685-4bda-a230-7c950f63157a} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrNull'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:08.974368 [ 6609 ] {070b2007-895a-4cd6-af79-f2c80eb311f9} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTime64OrZero([], []);) 2025.10.23 23:32:08.984456 [ 6609 ] {070b2007-895a-4cd6-af79-f2c80eb311f9} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'string' to function 'toDateTime64OrZero'. Expected: String or FixedString, got: Array(Nothing): In scope SELECT toDateTime64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.056269 [ 6609 ] {25e3a6a5-e1f4-40c1-9852-f4c9c44afed7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Array(Nothing): In scope SELECT toDateTimeOrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTimeOrDefault([], []);) 2025.10.23 23:32:09.066983 [ 6609 ] {25e3a6a5-e1f4-40c1-9852-f4c9c44afed7} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toDateTimeOrDefault'. Expected: const String, got: Array(Nothing): In scope SELECT toDateTimeOrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.124828 [ 2811 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:09.190918 [ 6609 ] {91f2b94d-77ad-45e0-bb8e-72b0cceb4554} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateTimeOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTimeOrNull([], []);) 2025.10.23 23:32:09.201162 [ 6609 ] {91f2b94d-77ad-45e0-bb8e-72b0cceb4554} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateTimeOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.281695 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:09.302298 [ 6609 ] {bcdf6edd-6f3c-417d-a84c-b9eac16c3755} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateTimeOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDateTimeOrZero([], []);) 2025.10.23 23:32:09.319491 [ 6609 ] {bcdf6edd-6f3c-417d-a84c-b9eac16c3755} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDateTimeOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDateTimeOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.373164 [ 2826 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:09.392455 [ 6609 ] {dadfce64-a60f-4a48-bd5d-c415f800c702} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDayOfMonth([], []);) 2025.10.23 23:32:09.405610 [ 6609 ] {dadfce64-a60f-4a48-bd5d-c415f800c702} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.412588 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:09.465853 [ 2830 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:09.518451 [ 6609 ] {b74f5a6b-e37e-4120-8fbc-2d9466e5bcb3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toDayOfWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDayOfWeek([], []);) 2025.10.23 23:32:09.523855 [ 6609 ] {b74f5a6b-e37e-4120-8fbc-2d9466e5bcb3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toDayOfWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.573378 [ 6609 ] {d5b03281-2a1c-4090-b006-f96197d9fa61} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDayOfYear([], []);) 2025.10.23 23:32:09.577028 [ 6609 ] {d5b03281-2a1c-4090-b006-f96197d9fa61} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDayOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDayOfYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.629019 [ 6609 ] {d3e385b3-3e81-47e0-9cef-30b8397b1273} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDaysSinceYearZero([], []);) 2025.10.23 23:32:09.634881 [ 6609 ] {d3e385b3-3e81-47e0-9cef-30b8397b1273} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toDaysSinceYearZero. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toDaysSinceYearZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.675164 [ 6609 ] {6e123fc4-fafc-4ae6-b446-6e4c0e5c04ef} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal128([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal128([], []);) 2025.10.23 23:32:09.680102 [ 6609 ] {6e123fc4-fafc-4ae6-b446-6e4c0e5c04ef} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal128([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.724146 [ 6609 ] {f32b6368-e169-4148-9876-83b8652b46d8} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal128OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal128OrDefault([], []);) 2025.10.23 23:32:09.730024 [ 6609 ] {f32b6368-e169-4148-9876-83b8652b46d8} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal128OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal128OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.786005 [ 6609 ] {765973e9-3f34-4b01-8f0e-3b49028758cb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal128OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal128OrNull([], []);) 2025.10.23 23:32:09.790168 [ 6609 ] {765973e9-3f34-4b01-8f0e-3b49028758cb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal128OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.842235 [ 6609 ] {00a138e2-b5f9-4f05-b7d3-211a8d4b4cc6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal128OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal128OrZero([], []);) 2025.10.23 23:32:09.847420 [ 6609 ] {00a138e2-b5f9-4f05-b7d3-211a8d4b4cc6} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal128OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:09.917947 [ 6609 ] {f0f14e76-e6cd-4bc3-b45b-e0773509e19f} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal256([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal256([], []);) 2025.10.23 23:32:09.928141 [ 6609 ] {f0f14e76-e6cd-4bc3-b45b-e0773509e19f} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal256([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.014834 [ 6609 ] {f1d6903c-4081-4520-b475-014cd9258cff} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal256OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal256OrDefault([], []);) 2025.10.23 23:32:10.040943 [ 6609 ] {f1d6903c-4081-4520-b475-014cd9258cff} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal256OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal256OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.127146 [ 2839 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:10.128984 [ 6609 ] {b04b4a30-9a8e-48cf-a8c5-d9c4f8b05101} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal256OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal256OrNull([], []);) 2025.10.23 23:32:10.148740 [ 6609 ] {b04b4a30-9a8e-48cf-a8c5-d9c4f8b05101} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal256OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.310244 [ 6609 ] {74f239b5-7074-477d-aec3-e45908a8a43c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal256OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal256OrZero([], []);) 2025.10.23 23:32:10.313242 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:10.315429 [ 6609 ] {74f239b5-7074-477d-aec3-e45908a8a43c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal256OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.375378 [ 2849 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:10.440429 [ 6609 ] {6837a62d-d793-462b-a657-376f1680c61d} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal32([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal32([], []);) 2025.10.23 23:32:10.446083 [ 6609 ] {6837a62d-d793-462b-a657-376f1680c61d} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal32([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.454319 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:10.470179 [ 2846 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:10.571395 [ 6609 ] {abcd2f82-01c4-41ff-92c5-b183e95ce6c7} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal32OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal32OrDefault([], []);) 2025.10.23 23:32:10.575765 [ 6609 ] {abcd2f82-01c4-41ff-92c5-b183e95ce6c7} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal32OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal32OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.647668 [ 6609 ] {db559c0c-4ca9-4af5-a544-13d8fe79b06e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal32OrNull([], []);) 2025.10.23 23:32:10.667456 [ 6609 ] {db559c0c-4ca9-4af5-a544-13d8fe79b06e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.713909 [ 6609 ] {e9107462-8bae-48c7-820d-2b57e8774e5b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal32OrZero([], []);) 2025.10.23 23:32:10.719272 [ 6609 ] {e9107462-8bae-48c7-820d-2b57e8774e5b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.776098 [ 6609 ] {1247e723-3d06-4f8a-b6c6-3cd89d444c94} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal64([], []);) 2025.10.23 23:32:10.779762 [ 6609 ] {1247e723-3d06-4f8a-b6c6-3cd89d444c94} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal64([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.853702 [ 6609 ] {5a6ebece-df93-404c-b66f-7da5cdaf6947} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal64OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal64OrDefault([], []);) 2025.10.23 23:32:10.859031 [ 6609 ] {5a6ebece-df93-404c-b66f-7da5cdaf6947} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'scale' to function 'toDecimal64OrDefault'. Expected: const Integer, got: Array(Nothing): In scope SELECT toDecimal64OrDefault([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:10.958512 [ 6609 ] {c8fb0e4d-4c45-42df-8438-f1eb842f1bd0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal64OrNull([], []);) 2025.10.23 23:32:10.964051 [ 6609 ] {c8fb0e4d-4c45-42df-8438-f1eb842f1bd0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:11.076935 [ 6609 ] {52380223-45b8-431d-bcf2-a3b81a8f4b47} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimal64OrZero([], []);) 2025.10.23 23:32:11.092854 [ 6609 ] {52380223-45b8-431d-bcf2-a3b81a8f4b47} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toDecimal64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toDecimal64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:11.174285 [ 2853 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:11.256548 [ 6609 ] {eefea220-8e57-46e1-adb8-b7890991d3e5} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'Value' to function 'toDecimalString'. Expected: Number, got: Array(Nothing): In scope SELECT toDecimalString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toDecimalString([], []);) 2025.10.23 23:32:11.258940 [ 6609 ] {eefea220-8e57-46e1-adb8-b7890991d3e5} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'Value' to function 'toDecimalString'. Expected: Number, got: Array(Nothing): In scope SELECT toDecimalString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:11.339096 [ 6609 ] {12e25768-a898-4150-ac21-8ac0cb742d50} executeQuery: Code: 44. DB::Exception: Second argument for function toFixedString must be unsigned integer: In scope SELECT toFixedString([], []). (ILLEGAL_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFixedString([], []);) 2025.10.23 23:32:11.355171 [ 6609 ] {12e25768-a898-4150-ac21-8ac0cb742d50} TCPHandler: Code: 44. DB::Exception: Second argument for function toFixedString must be unsigned integer: In scope SELECT toFixedString([], []). (ILLEGAL_COLUMN) 2025.10.23 23:32:11.361376 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:11.377750 [ 2865 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:11.464373 [ 6609 ] {71231052-d6a5-407a-b9b9-be1989f98a0e} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 2 arguments: In scope SELECT toFloat32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFloat32([], []);) 2025.10.23 23:32:11.467840 [ 6609 ] {71231052-d6a5-407a-b9b9-be1989f98a0e} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat32'. Expected 1 argument, got 2 arguments: In scope SELECT toFloat32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:11.472185 [ 2870 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:11.505293 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:11.594696 [ 6609 ] {15847786-4f2c-4e77-8e56-40fa73c1c80e} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Array(Nothing): In scope SELECT toFloat32OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFloat32OrDefault([], []);) 2025.10.23 23:32:11.599938 [ 6609 ] {15847786-4f2c-4e77-8e56-40fa73c1c80e} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float32. Actual Array(Nothing): In scope SELECT toFloat32OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:11.651433 [ 6609 ] {d40e9c46-4388-4910-a8b4-ece5bcf1cf25} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFloat32OrNull([], []);) 2025.10.23 23:32:11.656114 [ 6609 ] {d40e9c46-4388-4910-a8b4-ece5bcf1cf25} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:11.720095 [ 6609 ] {ca4ee01b-807b-4408-bf70-b26ac9f33664} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFloat32OrZero([], []);) 2025.10.23 23:32:11.724494 [ 6609 ] {ca4ee01b-807b-4408-bf70-b26ac9f33664} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:11.769161 [ 6609 ] {0f05d529-a718-41a6-9f60-777fa22c2174} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 2 arguments: In scope SELECT toFloat64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFloat64([], []);) 2025.10.23 23:32:11.774220 [ 6609 ] {0f05d529-a718-41a6-9f60-777fa22c2174} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toFloat64'. Expected 1 argument, got 2 arguments: In scope SELECT toFloat64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:11.821392 [ 6609 ] {48396323-bf2a-4498-840f-b1b82048b13b} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Array(Nothing): In scope SELECT toFloat64OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFloat64OrDefault([], []);) 2025.10.23 23:32:11.825110 [ 6609 ] {48396323-bf2a-4498-840f-b1b82048b13b} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Float64. Actual Array(Nothing): In scope SELECT toFloat64OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:11.909137 [ 6609 ] {c350561e-ad02-47e6-a876-fd734e041bcc} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFloat64OrNull([], []);) 2025.10.23 23:32:11.911607 [ 6609 ] {c350561e-ad02-47e6-a876-fd734e041bcc} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:11.958884 [ 6609 ] {da605d99-3f5c-4a6a-9c6e-09a1cab4b91f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toFloat64OrZero([], []);) 2025.10.23 23:32:11.966455 [ 6609 ] {da605d99-3f5c-4a6a-9c6e-09a1cab4b91f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toFloat64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toFloat64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:12.127360 [ 6609 ] {a998385b-01c8-4960-b40d-ca4391dbcab5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toHour([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toHour([], []);) 2025.10.23 23:32:12.130312 [ 6609 ] {a998385b-01c8-4960-b40d-ca4391dbcab5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toHour([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:12.176385 [ 2872 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:12.262663 [ 6609 ] {d570d13f-3220-434a-96be-eb6f1e708259} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 2 arguments: In scope SELECT toIPv4([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIPv4([], []);) 2025.10.23 23:32:12.274490 [ 6609 ] {d570d13f-3220-434a-96be-eb6f1e708259} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv4'. Expected 1 argument, got 2 arguments: In scope SELECT toIPv4([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:12.354138 [ 6609 ] {52c05ef7-73ed-4da7-8deb-a46d9e6168e3} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Array(Nothing): In scope SELECT toIPv4OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIPv4OrDefault([], []);) 2025.10.23 23:32:12.358398 [ 6609 ] {52c05ef7-73ed-4da7-8deb-a46d9e6168e3} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv4. Actual Array(Nothing): In scope SELECT toIPv4OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:12.384535 [ 2880 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:12.408329 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:12.474381 [ 2879 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:12.491112 [ 6609 ] {5ce4092b-c441-4163-b415-03f4bd22dd6c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv4OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIPv4OrNull([], []);) 2025.10.23 23:32:12.498344 [ 6609 ] {5ce4092b-c441-4163-b415-03f4bd22dd6c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv4OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:12.555738 [ 6609 ] {c3df8cb9-3581-4fc3-a014-ed5340006f6b} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv4OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIPv4OrZero([], []);) 2025.10.23 23:32:12.558394 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:12.560297 [ 6609 ] {c3df8cb9-3581-4fc3-a014-ed5340006f6b} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv4OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv4OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:12.665274 [ 6609 ] {ddbd4d66-060d-4faa-a8d2-1f3fcd41f2cb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 2 arguments: In scope SELECT toIPv6([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIPv6([], []);) 2025.10.23 23:32:12.668212 [ 6609 ] {ddbd4d66-060d-4faa-a8d2-1f3fcd41f2cb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIPv6'. Expected 1 argument, got 2 arguments: In scope SELECT toIPv6([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:12.836005 [ 6609 ] {4be19243-7230-4f7b-b66a-27c03d4ecdd7} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Array(Nothing): In scope SELECT toIPv6OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIPv6OrDefault([], []);) 2025.10.23 23:32:12.851475 [ 6609 ] {4be19243-7230-4f7b-b66a-27c03d4ecdd7} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected IPv6. Actual Array(Nothing): In scope SELECT toIPv6OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:12.904063 [ 6609 ] {7de1572b-1b97-4efb-abfc-7156612db0da} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv6OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIPv6OrNull([], []);) 2025.10.23 23:32:12.908874 [ 6609 ] {7de1572b-1b97-4efb-abfc-7156612db0da} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv6OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:12.961300 [ 6609 ] {86b97ca8-13ed-4543-bd34-2a87a68223c6} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv6OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIPv6OrZero([], []);) 2025.10.23 23:32:12.965842 [ 6609 ] {86b97ca8-13ed-4543-bd34-2a87a68223c6} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toIPv6OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toIPv6OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:13.016175 [ 6609 ] {1f863eb3-10be-42c3-a7ad-a1f93a2f0d59} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toISOWeek. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toISOWeek([], []);) 2025.10.23 23:32:13.024555 [ 6609 ] {1f863eb3-10be-42c3-a7ad-a1f93a2f0d59} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toISOWeek. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:13.112911 [ 6609 ] {30d84c6d-3fa9-46f9-b5c4-5d93e32ef3dd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toISOYear([], []);) 2025.10.23 23:32:13.117552 [ 6609 ] {30d84c6d-3fa9-46f9-b5c4-5d93e32ef3dd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toISOYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:13.178501 [ 2891 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:13.283431 [ 6609 ] {1c207d2a-bc40-4bb9-9d11-a9d9e3083bb0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 2 arguments: In scope SELECT toInt128([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt128([], []);) 2025.10.23 23:32:13.299774 [ 6609 ] {1c207d2a-bc40-4bb9-9d11-a9d9e3083bb0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt128'. Expected 1 argument, got 2 arguments: In scope SELECT toInt128([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:13.386665 [ 2896 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:13.400555 [ 6609 ] {896b1061-932c-4889-ac88-a7da8d4b3c08} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Array(Nothing): In scope SELECT toInt128OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt128OrDefault([], []);) 2025.10.23 23:32:13.405843 [ 6609 ] {896b1061-932c-4889-ac88-a7da8d4b3c08} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int128. Actual Array(Nothing): In scope SELECT toInt128OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:13.451300 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:13.467002 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:13.476453 [ 2893 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:13.498238 [ 6609 ] {64b54da8-9e19-4ef1-a799-541e97166dbb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt128OrNull([], []);) 2025.10.23 23:32:13.503182 [ 6609 ] {64b54da8-9e19-4ef1-a799-541e97166dbb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:13.604442 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:13.664922 [ 6609 ] {a5786df2-037f-46bc-bcbe-b769e30a920f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt128OrZero([], []);) 2025.10.23 23:32:13.669267 [ 6609 ] {a5786df2-037f-46bc-bcbe-b769e30a920f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt128OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:13.774857 [ 6609 ] {63695347-f8b1-437d-a4fa-0de53912cc7f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 2 arguments: In scope SELECT toInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt16([], []);) 2025.10.23 23:32:13.779939 [ 6609 ] {63695347-f8b1-437d-a4fa-0de53912cc7f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt16'. Expected 1 argument, got 2 arguments: In scope SELECT toInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:13.854346 [ 3621 ] {9d7b017e-151e-4b1e-9716-3079e02863c2} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:13.857945 [ 3621 ] {9d7b017e-151e-4b1e-9716-3079e02863c2} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:13.863439 [ 6609 ] {aafc9346-12f4-438e-8af3-4654a1bce8fb} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Array(Nothing): In scope SELECT toInt16OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt16OrDefault([], []);) 2025.10.23 23:32:13.868621 [ 6609 ] {aafc9346-12f4-438e-8af3-4654a1bce8fb} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int16. Actual Array(Nothing): In scope SELECT toInt16OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:13.874654 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (12 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:13.913177 [ 6609 ] {f1732e5a-7978-4558-a5eb-1c7260c8271c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt16OrNull([], []);) 2025.10.23 23:32:13.919805 [ 6609 ] {f1732e5a-7978-4558-a5eb-1c7260c8271c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:13.969267 [ 6609 ] {d5507b70-fe92-4ce0-a7e6-6f9870903994} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt16OrZero([], []);) 2025.10.23 23:32:13.973156 [ 6609 ] {d5507b70-fe92-4ce0-a7e6-6f9870903994} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt16OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:14.117960 [ 6609 ] {e2a8b2b2-52a3-4fb4-8029-933eb59364e9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 2 arguments: In scope SELECT toInt256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt256([], []);) 2025.10.23 23:32:14.124753 [ 6609 ] {e2a8b2b2-52a3-4fb4-8029-933eb59364e9} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt256'. Expected 1 argument, got 2 arguments: In scope SELECT toInt256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:14.186838 [ 2902 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:14.229132 [ 6609 ] {5a120015-1385-490d-846a-8325d22f8d38} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Array(Nothing): In scope SELECT toInt256OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt256OrDefault([], []);) 2025.10.23 23:32:14.234381 [ 6609 ] {5a120015-1385-490d-846a-8325d22f8d38} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int256. Actual Array(Nothing): In scope SELECT toInt256OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:14.380455 [ 6609 ] {79d9e11b-b774-45a4-b8f1-b52515ff52e2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt256OrNull([], []);) 2025.10.23 23:32:14.385611 [ 6609 ] {79d9e11b-b774-45a4-b8f1-b52515ff52e2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:14.388579 [ 2910 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:14.485574 [ 2802 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:14.522486 [ 6609 ] {d92e2a14-fe1a-41f0-a222-d0a5189a86e0} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt256OrZero([], []);) 2025.10.23 23:32:14.527764 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:14.529663 [ 6609 ] {d92e2a14-fe1a-41f0-a222-d0a5189a86e0} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt256OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:14.659950 [ 6609 ] {30d59f27-abb4-4bf7-a37a-3be7ffabe29d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 2 arguments: In scope SELECT toInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt32([], []);) 2025.10.23 23:32:14.665194 [ 6609 ] {30d59f27-abb4-4bf7-a37a-3be7ffabe29d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt32'. Expected 1 argument, got 2 arguments: In scope SELECT toInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:14.665368 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:14.778680 [ 6609 ] {3d0dc634-4359-4f09-b4d1-d7a48c5e4321} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Array(Nothing): In scope SELECT toInt32OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt32OrDefault([], []);) 2025.10.23 23:32:14.784252 [ 6609 ] {3d0dc634-4359-4f09-b4d1-d7a48c5e4321} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int32. Actual Array(Nothing): In scope SELECT toInt32OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:14.845180 [ 6609 ] {861f26ac-dce5-4f5e-8234-65bf01ab686d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt32OrNull([], []);) 2025.10.23 23:32:14.876813 [ 6609 ] {861f26ac-dce5-4f5e-8234-65bf01ab686d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:14.935857 [ 6609 ] {ecd48c63-457f-4d56-9fb3-14faf3653c1e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt32OrZero([], []);) 2025.10.23 23:32:14.939349 [ 6609 ] {ecd48c63-457f-4d56-9fb3-14faf3653c1e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:15.075867 [ 6609 ] {938ea051-1a41-4eac-9a3d-720df152b63c} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 2 arguments: In scope SELECT toInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt64([], []);) 2025.10.23 23:32:15.079285 [ 6609 ] {938ea051-1a41-4eac-9a3d-720df152b63c} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt64'. Expected 1 argument, got 2 arguments: In scope SELECT toInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:15.145118 [ 6609 ] {de2819c3-0b05-4ee9-bcd4-a1a6717c2ba6} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Array(Nothing): In scope SELECT toInt64OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt64OrDefault([], []);) 2025.10.23 23:32:15.163974 [ 6609 ] {de2819c3-0b05-4ee9-bcd4-a1a6717c2ba6} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int64. Actual Array(Nothing): In scope SELECT toInt64OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:15.189220 [ 2922 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:15.269658 [ 6609 ] {8b1c3255-bad7-4ec1-b39a-952e14d1c9e1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt64OrNull([], []);) 2025.10.23 23:32:15.278892 [ 6609 ] {8b1c3255-bad7-4ec1-b39a-952e14d1c9e1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:15.390757 [ 2923 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:15.410536 [ 6609 ] {c7bd8eec-c273-4812-92e6-84316e791ee9} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt64OrZero([], []);) 2025.10.23 23:32:15.429612 [ 6609 ] {c7bd8eec-c273-4812-92e6-84316e791ee9} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:15.487558 [ 2926 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:15.544483 [ 6609 ] {cb27cb34-f073-47e9-86ba-af6b770be271} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 2 arguments: In scope SELECT toInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt8([], []);) 2025.10.23 23:32:15.561738 [ 6609 ] {cb27cb34-f073-47e9-86ba-af6b770be271} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toInt8'. Expected 1 argument, got 2 arguments: In scope SELECT toInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:15.631507 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:15.663377 [ 6609 ] {ca9235a6-1f21-4a64-a46a-22a81b3c4021} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Array(Nothing): In scope SELECT toInt8OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt8OrDefault([], []);) 2025.10.23 23:32:15.677912 [ 6609 ] {ca9235a6-1f21-4a64-a46a-22a81b3c4021} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected Int8. Actual Array(Nothing): In scope SELECT toInt8OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:15.685189 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:15.783583 [ 6609 ] {64a18d7e-c522-4a2e-adbe-a5c228beb4a3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt8OrNull([], []);) 2025.10.23 23:32:15.787793 [ 6609 ] {64a18d7e-c522-4a2e-adbe-a5c228beb4a3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:15.838839 [ 6609 ] {14eb3611-b2fc-4244-b517-5a453f9dff3d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toInt8OrZero([], []);) 2025.10.23 23:32:15.843560 [ 6609 ] {14eb3611-b2fc-4244-b517-5a453f9dff3d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toInt8OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:15.890791 [ 6609 ] {9d6e5469-3a1a-4ec1-974c-7062f398858f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalDay([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalDay([], []);) 2025.10.23 23:32:15.895137 [ 6609 ] {9d6e5469-3a1a-4ec1-974c-7062f398858f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalDay'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalDay([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:15.944130 [ 6609 ] {f7b4681f-62a3-4449-b1a3-f28ae58390eb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalHour([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalHour([], []);) 2025.10.23 23:32:15.950447 [ 6609 ] {f7b4681f-62a3-4449-b1a3-f28ae58390eb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalHour'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalHour([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.059212 [ 6609 ] {9411ba6e-677a-4814-a8f8-0b65c474e457} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalMicrosecond([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalMicrosecond([], []);) 2025.10.23 23:32:16.062838 [ 6609 ] {9411ba6e-677a-4814-a8f8-0b65c474e457} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMicrosecond'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalMicrosecond([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.178468 [ 6609 ] {38a35855-c3fa-4829-a7a1-6418fe275a60} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalMillisecond([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalMillisecond([], []);) 2025.10.23 23:32:16.183592 [ 6609 ] {38a35855-c3fa-4829-a7a1-6418fe275a60} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMillisecond'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalMillisecond([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.191484 [ 2939 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:16.359536 [ 6609 ] {948ef6a6-5a38-41a6-a695-85770571170b} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalMinute([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalMinute([], []);) 2025.10.23 23:32:16.364415 [ 6609 ] {948ef6a6-5a38-41a6-a695-85770571170b} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMinute'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalMinute([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.393209 [ 2943 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:16.468555 [ 6609 ] {7205e82c-bbc0-4aee-adff-cb8e7f8b7a2f} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalMonth([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalMonth([], []);) 2025.10.23 23:32:16.484782 [ 6609 ] {7205e82c-bbc0-4aee-adff-cb8e7f8b7a2f} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalMonth'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalMonth([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.489528 [ 2947 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:16.640403 [ 6609 ] {49c329e3-77ca-4e5d-9637-6d82d22ce9cc} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalNanosecond([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalNanosecond([], []);) 2025.10.23 23:32:16.648439 [ 6609 ] {49c329e3-77ca-4e5d-9637-6d82d22ce9cc} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalNanosecond'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalNanosecond([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.685333 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:16.723108 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:16.743911 [ 6609 ] {33186c9a-a937-4a92-9131-7ae0fd2fb78d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalQuarter([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalQuarter([], []);) 2025.10.23 23:32:16.749396 [ 6609 ] {33186c9a-a937-4a92-9131-7ae0fd2fb78d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalQuarter'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalQuarter([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.834444 [ 6609 ] {a80fe5e3-65c5-4e63-a1ec-c88f4c16f3cb} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalSecond([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalSecond([], []);) 2025.10.23 23:32:16.839272 [ 6609 ] {a80fe5e3-65c5-4e63-a1ec-c88f4c16f3cb} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalSecond'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalSecond([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.888277 [ 6609 ] {13d7a020-360b-49e5-8a4e-74580c678b32} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalWeek([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalWeek([], []);) 2025.10.23 23:32:16.893632 [ 6609 ] {13d7a020-360b-49e5-8a4e-74580c678b32} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalWeek'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalWeek([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.932989 [ 6609 ] {445e413b-f855-4cdc-945d-85ebd652b8c0} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalYear([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toIntervalYear([], []);) 2025.10.23 23:32:16.937441 [ 6609 ] {445e413b-f855-4cdc-945d-85ebd652b8c0} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toIntervalYear'. Expected 1 argument, got 2 arguments: In scope SELECT toIntervalYear([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:16.985930 [ 6609 ] {08fd9fea-949f-4dd8-a4dd-829490eedd71} executeQuery: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toJSONString([], []);) 2025.10.23 23:32:16.991321 [ 6609 ] {08fd9fea-949f-4dd8-a4dd-829490eedd71} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toJSONString doesn't match: passed 2, should be 1: In scope SELECT toJSONString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:17.038859 [ 6609 ] {d25f6a5a-a8e6-41e0-9893-6351db89adc5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toLastDayOfMonth([], []);) 2025.10.23 23:32:17.044454 [ 6609 ] {d25f6a5a-a8e6-41e0-9893-6351db89adc5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toLastDayOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toLastDayOfMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:17.099250 [ 6609 ] {1a8be5f4-36fe-41c1-9735-5cdad0190549} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toLastDayOfWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toLastDayOfWeek([], []);) 2025.10.23 23:32:17.105547 [ 6609 ] {1a8be5f4-36fe-41c1-9735-5cdad0190549} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toLastDayOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toLastDayOfWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:17.158193 [ 6609 ] {55937c8d-2fa4-4362-9216-27411642cb21} executeQuery: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toLowCardinality([], []);) 2025.10.23 23:32:17.163323 [ 6609 ] {55937c8d-2fa4-4362-9216-27411642cb21} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toLowCardinality doesn't match: passed 2, should be 1: In scope SELECT toLowCardinality([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:17.200599 [ 2956 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:17.206590 [ 6609 ] {5ad846f0-f072-4b89-867f-7e5d831a04fe} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toMillisecond([], []);) 2025.10.23 23:32:17.211792 [ 6609 ] {5ad846f0-f072-4b89-867f-7e5d831a04fe} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMillisecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:17.251580 [ 6609 ] {5f6e7c32-d33a-4269-a114-2f77e7bf5448} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMinute([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toMinute([], []);) 2025.10.23 23:32:17.255609 [ 6609 ] {5f6e7c32-d33a-4269-a114-2f77e7bf5448} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMinute([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:17.321954 [ 6609 ] {b40e1e07-6175-405b-adc1-4a2a0d166c54} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toModifiedJulianDay([], []);) 2025.10.23 23:32:17.337715 [ 6609 ] {b40e1e07-6175-405b-adc1-4a2a0d166c54} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDay doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDay([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:17.395517 [ 2955 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:17.457329 [ 6609 ] {fd551f5f-0234-408d-8120-0fce1b40bc5f} executeQuery: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toModifiedJulianDayOrNull([], []);) 2025.10.23 23:32:17.463937 [ 6609 ] {fd551f5f-0234-408d-8120-0fce1b40bc5f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toModifiedJulianDayOrNull doesn't match: passed 2, should be 1: In scope SELECT toModifiedJulianDayOrNull([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:17.491529 [ 2958 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:17.579664 [ 6609 ] {d1983ae4-ccd3-4d14-b72b-23be22681f9a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonday. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonday([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toMonday([], []);) 2025.10.23 23:32:17.586223 [ 6609 ] {d1983ae4-ccd3-4d14-b72b-23be22681f9a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonday. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonday([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:17.674617 [ 6609 ] {00d223dd-00e2-453f-b0b9-dbbe52245207} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toMonth([], []);) 2025.10.23 23:32:17.684231 [ 6609 ] {00d223dd-00e2-453f-b0b9-dbbe52245207} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:17.709343 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:17.750666 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:17.754845 [ 6609 ] {cf2e3f85-82fd-4026-b7e2-1eb4691dadb6} executeQuery: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toNullable([], []);) 2025.10.23 23:32:17.769192 [ 6609 ] {cf2e3f85-82fd-4026-b7e2-1eb4691dadb6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toNullable doesn't match: passed 2, should be 1: In scope SELECT toNullable([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:17.870691 [ 6609 ] {b9af7709-45c9-435e-9fb2-a858ec7a3c47} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toQuarter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toQuarter([], []);) 2025.10.23 23:32:17.873919 [ 6609 ] {b9af7709-45c9-435e-9fb2-a858ec7a3c47} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toQuarter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:17.914358 [ 6609 ] {e41c67d2-b2e6-4cfc-ad16-0993735bd023} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeDayNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeDayNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toRelativeDayNum([], []);) 2025.10.23 23:32:17.918867 [ 6609 ] {e41c67d2-b2e6-4cfc-ad16-0993735bd023} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeDayNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeDayNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:18.051796 [ 6609 ] {fba2efda-9243-456f-9124-5431b6b1b913} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeHourNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeHourNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toRelativeHourNum([], []);) 2025.10.23 23:32:18.066164 [ 6609 ] {fba2efda-9243-456f-9124-5431b6b1b913} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeHourNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeHourNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:18.202784 [ 2965 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:18.243788 [ 6609 ] {95b7859e-0fdf-46db-a2bb-a136cc4ab0b5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeMinuteNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMinuteNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toRelativeMinuteNum([], []);) 2025.10.23 23:32:18.249546 [ 6609 ] {95b7859e-0fdf-46db-a2bb-a136cc4ab0b5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeMinuteNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMinuteNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:18.290171 [ 6609 ] {7bd119d3-e702-4f32-96e0-465a93429c55} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeMonthNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMonthNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toRelativeMonthNum([], []);) 2025.10.23 23:32:18.317695 [ 6609 ] {7bd119d3-e702-4f32-96e0-465a93429c55} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeMonthNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeMonthNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:18.397528 [ 2970 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:18.428900 [ 6609 ] {fc76d08e-48b2-498d-8f1d-21a822c7eedb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeQuarterNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeQuarterNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toRelativeQuarterNum([], []);) 2025.10.23 23:32:18.446900 [ 6609 ] {fc76d08e-48b2-498d-8f1d-21a822c7eedb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeQuarterNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeQuarterNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:18.493600 [ 2964 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:18.525630 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:18.527053 [ 6609 ] {9b623c6a-7806-4b1d-ba59-72b3d10c8e64} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeSecondNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeSecondNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toRelativeSecondNum([], []);) 2025.10.23 23:32:18.533526 [ 6609 ] {9b623c6a-7806-4b1d-ba59-72b3d10c8e64} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeSecondNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeSecondNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:18.655674 [ 6609 ] {a853ac73-6aff-4a8b-965d-73969d51c94f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeWeekNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeWeekNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toRelativeWeekNum([], []);) 2025.10.23 23:32:18.668630 [ 6609 ] {a853ac73-6aff-4a8b-965d-73969d51c94f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeWeekNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeWeekNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:18.735820 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:18.737278 [ 6609 ] {74b2e166-7f7e-4cc0-8a83-38b733e2c09f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeYearNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeYearNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toRelativeYearNum([], []);) 2025.10.23 23:32:18.743988 [ 6609 ] {74b2e166-7f7e-4cc0-8a83-38b733e2c09f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toRelativeYearNum. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toRelativeYearNum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:18.794908 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:18.895616 [ 6609 ] {300536b0-5524-4772-ada2-ea00502fe568} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toSecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toSecond([], []);) 2025.10.23 23:32:18.900220 [ 6609 ] {300536b0-5524-4772-ada2-ea00502fe568} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toSecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:19.006446 [ 6609 ] {6ff21737-090c-4764-a7db-eef1bd681c75} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfDay. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfDay([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfDay([], []);) 2025.10.23 23:32:19.011246 [ 6609 ] {6ff21737-090c-4764-a7db-eef1bd681c75} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfDay. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfDay([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:19.059478 [ 6609 ] {7b572076-051a-4de2-bc92-8fe402871f5d} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFifteenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFifteenMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfFifteenMinutes([], []);) 2025.10.23 23:32:19.064171 [ 6609 ] {7b572076-051a-4de2-bc92-8fe402871f5d} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFifteenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFifteenMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:19.137132 [ 6609 ] {cfca1bd9-ad61-444e-b6c0-d3b6d40d1c26} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinute([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfFiveMinute([], []);) 2025.10.23 23:32:19.145980 [ 6609 ] {cfca1bd9-ad61-444e-b6c0-d3b6d40d1c26} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinute([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:19.204999 [ 2983 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:19.209556 [ 3621 ] {4bde9d15-5458-45dc-9612-4d9433d6e200} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:19.211587 [ 3621 ] {4bde9d15-5458-45dc-9612-4d9433d6e200} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:19.220646 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (13 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:19.321728 [ 6609 ] {3efed9c8-7983-4b63-8108-fd1ec8ddaac5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfFiveMinutes([], []);) 2025.10.23 23:32:19.324599 [ 6609 ] {3efed9c8-7983-4b63-8108-fd1ec8ddaac5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfFiveMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfFiveMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:19.399958 [ 2985 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:19.432688 [ 6609 ] {1ba5db54-4340-47a3-bab3-6b11e9fe4750} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfHour([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfHour([], []);) 2025.10.23 23:32:19.455446 [ 6609 ] {1ba5db54-4340-47a3-bab3-6b11e9fe4750} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfHour. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfHour([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:19.495487 [ 2988 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:19.614749 [ 6609 ] {fb75d76a-d639-40db-b83a-36b831b20f18} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfISOYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfISOYear([], []);) 2025.10.23 23:32:19.621537 [ 6609 ] {fb75d76a-d639-40db-b83a-36b831b20f18} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfISOYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfISOYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:19.770302 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:19.778626 [ 6609 ] {0d207092-6d6c-4cba-b8fb-764589235cb1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfInterval, expected a Date, DateTime or DateTime64: In scope SELECT toStartOfInterval([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfInterval([], []);) 2025.10.23 23:32:19.795907 [ 6609 ] {0d207092-6d6c-4cba-b8fb-764589235cb1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfInterval, expected a Date, DateTime or DateTime64: In scope SELECT toStartOfInterval([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:19.843963 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:19.962533 [ 6609 ] {11977f7a-9cf9-4c05-a5c4-f5a7805c2163} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMicrosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMicrosecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfMicrosecond([], []);) 2025.10.23 23:32:19.966219 [ 6609 ] {11977f7a-9cf9-4c05-a5c4-f5a7805c2163} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMicrosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMicrosecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.025378 [ 6609 ] {084a7464-3521-41b5-8cf7-d71dea8268cd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMillisecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfMillisecond([], []);) 2025.10.23 23:32:20.029220 [ 6609 ] {084a7464-3521-41b5-8cf7-d71dea8268cd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMillisecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMillisecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.079093 [ 6609 ] {d539f87b-bf50-4145-84f6-67cb50f31caf} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMinute([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfMinute([], []);) 2025.10.23 23:32:20.083238 [ 6609 ] {d539f87b-bf50-4145-84f6-67cb50f31caf} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMinute. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMinute([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.128480 [ 6609 ] {5ed66fd3-cda9-4bb6-8e1f-8a6b5909131a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfMonth([], []);) 2025.10.23 23:32:20.131921 [ 6609 ] {5ed66fd3-cda9-4bb6-8e1f-8a6b5909131a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfMonth. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfMonth([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.207332 [ 2994 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:20.333762 [ 6609 ] {580e692a-18cc-47ee-8cbc-73cf21ea197a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfNanosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfNanosecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfNanosecond([], []);) 2025.10.23 23:32:20.338034 [ 6609 ] {580e692a-18cc-47ee-8cbc-73cf21ea197a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfNanosecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfNanosecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.400019 [ 6609 ] {2adb1ff9-f647-4e4a-8701-890fe0ec0937} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfQuarter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfQuarter([], []);) 2025.10.23 23:32:20.401937 [ 3004 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:20.408322 [ 6609 ] {2adb1ff9-f647-4e4a-8701-890fe0ec0937} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfQuarter. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfQuarter([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.497460 [ 3003 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:20.532991 [ 6609 ] {6b01cd70-b1fd-4fdc-8cb4-d1fd79631842} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfSecond([], []);) 2025.10.23 23:32:20.549598 [ 6609 ] {6b01cd70-b1fd-4fdc-8cb4-d1fd79631842} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfSecond. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfSecond([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.687542 [ 6609 ] {6969d509-9635-4e98-bfff-a4e8af6fcec4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfTenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfTenMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfTenMinutes([], []);) 2025.10.23 23:32:20.702354 [ 6609 ] {6969d509-9635-4e98-bfff-a4e8af6fcec4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfTenMinutes. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfTenMinutes([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.812281 [ 6609 ] {b63e9c0d-75fe-47fa-90a9-6da60abe117c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toStartOfWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfWeek([], []);) 2025.10.23 23:32:20.823341 [ 6609 ] {b63e9c0d-75fe-47fa-90a9-6da60abe117c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toStartOfWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toStartOfWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:20.850365 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:20.883888 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:20.904864 [ 6609 ] {bb113140-ce75-4d55-87b0-ea1da2e2fca5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStartOfYear([], []);) 2025.10.23 23:32:20.998071 [ 6609 ] {bb113140-ce75-4d55-87b0-ea1da2e2fca5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toStartOfYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toStartOfYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:21.044544 [ 6609 ] {aa2a3c99-db0f-424d-80ae-fea94ff76cec} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 2 arguments: In scope SELECT toString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toString([], []);) 2025.10.23 23:32:21.047890 [ 6609 ] {aa2a3c99-db0f-424d-80ae-fea94ff76cec} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toString'. Expected 1 argument, got 2 arguments: In scope SELECT toString([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:21.092901 [ 6609 ] {418eca21-4c11-4229-8a8d-d0e0b18014ef} executeQuery: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toStringCutToZero([], []);) 2025.10.23 23:32:21.097695 [ 6609 ] {418eca21-4c11-4229-8a8d-d0e0b18014ef} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toStringCutToZero doesn't match: passed 2, should be 1: In scope SELECT toStringCutToZero([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:21.145716 [ 6609 ] {56a7d5a2-ec6f-4da1-b9c9-20b7cd557c3c} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toTime. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toTime([], []);) 2025.10.23 23:32:21.150809 [ 6609 ] {56a7d5a2-ec6f-4da1-b9c9-20b7cd557c3c} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toTime. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toTime([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:21.189595 [ 6609 ] {ab9dcffd-89e0-4496-b29d-d2b311862c0f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toTimezone. Should be DateTime or DateTime64: In scope SELECT toTimeZone([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toTimeZone([], []);) 2025.10.23 23:32:21.193024 [ 6609 ] {ab9dcffd-89e0-4496-b29d-d2b311862c0f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toTimezone. Should be DateTime or DateTime64: In scope SELECT toTimeZone([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:21.211698 [ 3013 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:21.237367 [ 6609 ] {4e4d8476-a6eb-41f0-a927-593d944ef0ee} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toTimezone. Should be DateTime or DateTime64: In scope SELECT toTimezone([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toTimezone([], []);) 2025.10.23 23:32:21.242211 [ 6609 ] {4e4d8476-a6eb-41f0-a927-593d944ef0ee} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toTimezone. Should be DateTime or DateTime64: In scope SELECT toTimezone([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:21.404009 [ 3015 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:21.435643 [ 6609 ] {94e5d515-fc01-4b11-8f06-a20417ad95f2} executeQuery: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toTypeName([], []);) 2025.10.23 23:32:21.438645 [ 6609 ] {94e5d515-fc01-4b11-8f06-a20417ad95f2} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toTypeName doesn't match: passed 2, should be 1: In scope SELECT toTypeName([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:21.499444 [ 2998 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:21.554420 [ 6609 ] {a9dd9a1e-aaef-4c72-b135-4f3ed045e8d6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt128([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt128([], []);) 2025.10.23 23:32:21.566482 [ 6609 ] {a9dd9a1e-aaef-4c72-b135-4f3ed045e8d6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt128'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt128([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:21.675639 [ 6609 ] {3af23b91-978d-4a2d-9896-14d7515985ab} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Array(Nothing): In scope SELECT toUInt128OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt128OrDefault([], []);) 2025.10.23 23:32:21.685968 [ 6609 ] {3af23b91-978d-4a2d-9896-14d7515985ab} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt128. Actual Array(Nothing): In scope SELECT toUInt128OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:21.775918 [ 6609 ] {8a60d74b-6810-4f29-a580-005c24e206d7} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt128OrNull([], []);) 2025.10.23 23:32:21.791017 [ 6609 ] {8a60d74b-6810-4f29-a580-005c24e206d7} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt128OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:21.884680 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:21.899710 [ 6609 ] {4d810c35-f142-46d1-ad93-e3012ae55e89} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt128OrZero([], []);) 2025.10.23 23:32:21.903515 [ 6609 ] {4d810c35-f142-46d1-ad93-e3012ae55e89} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt128OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt128OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:21.927833 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:22.021992 [ 6609 ] {575fb760-0f46-4e7d-82f2-da5a543d7222} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt16([], []);) 2025.10.23 23:32:22.026908 [ 3383 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {855a1c57-459a-4184-97ab-17bc8cfce245::202510_1_66_13}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:22.028984 [ 6609 ] {575fb760-0f46-4e7d-82f2-da5a543d7222} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt16'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt16([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:22.075948 [ 6609 ] {e2865dbf-ac41-4f2b-a86f-a7753850a70f} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Array(Nothing): In scope SELECT toUInt16OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt16OrDefault([], []);) 2025.10.23 23:32:22.081165 [ 6609 ] {e2865dbf-ac41-4f2b-a86f-a7753850a70f} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt16. Actual Array(Nothing): In scope SELECT toUInt16OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:22.222475 [ 3032 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:22.223205 [ 6609 ] {9c0e452b-bd19-48af-a4b3-84f422a1d36e} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt16OrNull([], []);) 2025.10.23 23:32:22.313332 [ 6609 ] {9c0e452b-bd19-48af-a4b3-84f422a1d36e} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt16OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:22.343995 [ 6609 ] {ae15a324-adfc-4606-be95-dfb1dce89231} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt16OrZero([], []);) 2025.10.23 23:32:22.352359 [ 6609 ] {ae15a324-adfc-4606-be95-dfb1dce89231} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt16OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt16OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:22.395125 [ 6609 ] {8302a4a4-9d1c-44b3-9cc7-aa35b057a62d} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt256([], []);) 2025.10.23 23:32:22.398751 [ 6609 ] {8302a4a4-9d1c-44b3-9cc7-aa35b057a62d} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt256'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt256([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:22.406551 [ 3029 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:22.441438 [ 6609 ] {73a2187c-d65c-47af-86d5-25ccf286a835} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Array(Nothing): In scope SELECT toUInt256OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt256OrDefault([], []);) 2025.10.23 23:32:22.445950 [ 6609 ] {73a2187c-d65c-47af-86d5-25ccf286a835} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt256. Actual Array(Nothing): In scope SELECT toUInt256OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:22.488162 [ 6609 ] {8f89f17d-7187-4a1c-8116-027970475945} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt256OrNull([], []);) 2025.10.23 23:32:22.492674 [ 6609 ] {8f89f17d-7187-4a1c-8116-027970475945} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt256OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:22.504740 [ 3031 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:22.602700 [ 6609 ] {51438e94-17b5-4326-ae02-dcb727f5aef3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt256OrZero([], []);) 2025.10.23 23:32:22.615014 [ 6609 ] {51438e94-17b5-4326-ae02-dcb727f5aef3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt256OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt256OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:22.791933 [ 6609 ] {c4e7fa4c-ec41-466b-90c0-a7878253bbca} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt32([], []);) 2025.10.23 23:32:22.799325 [ 6609 ] {c4e7fa4c-ec41-466b-90c0-a7878253bbca} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt32'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt32([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:22.921197 [ 6609 ] {c06e175e-23c5-43ce-bda7-326b25e8c1e5} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Array(Nothing): In scope SELECT toUInt32OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt32OrDefault([], []);) 2025.10.23 23:32:22.925730 [ 6609 ] {c06e175e-23c5-43ce-bda7-326b25e8c1e5} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt32. Actual Array(Nothing): In scope SELECT toUInt32OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:22.936990 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:22.937293 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:23.055856 [ 6609 ] {83fcf03c-66df-4837-a1cd-bc805ad343ec} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt32OrNull([], []);) 2025.10.23 23:32:23.061188 [ 6609 ] {83fcf03c-66df-4837-a1cd-bc805ad343ec} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt32OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:23.106055 [ 6609 ] {7ce2027f-3421-45fe-806b-c71b62f04b9a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt32OrZero([], []);) 2025.10.23 23:32:23.110901 [ 6609 ] {7ce2027f-3421-45fe-806b-c71b62f04b9a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt32OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt32OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:23.224495 [ 3046 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:23.225769 [ 6609 ] {9b518e8b-45ec-4073-80ef-d07760b70ef9} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt64([], []);) 2025.10.23 23:32:23.292637 [ 6609 ] {9b518e8b-45ec-4073-80ef-d07760b70ef9} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt64'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt64([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:23.353784 [ 6609 ] {886d7229-42dc-4a12-a09d-4781111f7b33} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Array(Nothing): In scope SELECT toUInt64OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt64OrDefault([], []);) 2025.10.23 23:32:23.365145 [ 6609 ] {886d7229-42dc-4a12-a09d-4781111f7b33} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt64. Actual Array(Nothing): In scope SELECT toUInt64OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:23.409689 [ 3051 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:23.411126 [ 6609 ] {cc603080-374f-4deb-b7b8-a5e8cd80a163} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt64OrNull([], []);) 2025.10.23 23:32:23.414498 [ 6609 ] {cc603080-374f-4deb-b7b8-a5e8cd80a163} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt64OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:23.460871 [ 6609 ] {74df4933-bcd8-4ad2-8097-91d0f05896ef} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt64OrZero([], []);) 2025.10.23 23:32:23.465535 [ 6609 ] {74df4933-bcd8-4ad2-8097-91d0f05896ef} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt64OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt64OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:23.507181 [ 3056 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:23.594031 [ 6609 ] {a434533c-4179-418c-8d8c-6170cd78f391} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt8([], []);) 2025.10.23 23:32:23.597679 [ 6609 ] {a434533c-4179-418c-8d8c-6170cd78f391} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUInt8'. Expected 1 argument, got 2 arguments: In scope SELECT toUInt8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:23.615933 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:23.687683 [ 6609 ] {06d50c82-d57d-4962-b9be-d91f24836465} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Array(Nothing): In scope SELECT toUInt8OrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt8OrDefault([], []);) 2025.10.23 23:32:23.698253 [ 6609 ] {06d50c82-d57d-4962-b9be-d91f24836465} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UInt8. Actual Array(Nothing): In scope SELECT toUInt8OrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:23.857855 [ 6609 ] {764c2838-020f-410c-97c1-186ca8e6b5d2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt8OrNull([], []);) 2025.10.23 23:32:23.871215 [ 6609 ] {764c2838-020f-410c-97c1-186ca8e6b5d2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt8OrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:23.960622 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:23.978685 [ 6609 ] {d2c9f77e-1f5e-49de-a269-dc3b0da69f16} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUInt8OrZero([], []);) 2025.10.23 23:32:23.981042 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:23.994520 [ 6609 ] {d2c9f77e-1f5e-49de-a269-dc3b0da69f16} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUInt8OrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUInt8OrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:24.085357 [ 6609 ] {9bbff248-8cb9-4284-ba5b-d725a9c23adb} executeQuery: Code: 43. DB::Exception: Function toUTCTimestamp's 1st argument type must be datetime.: In scope SELECT toUTCTimestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUTCTimestamp([], []);) 2025.10.23 23:32:24.089182 [ 6609 ] {9bbff248-8cb9-4284-ba5b-d725a9c23adb} TCPHandler: Code: 43. DB::Exception: Function toUTCTimestamp's 1st argument type must be datetime.: In scope SELECT toUTCTimestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:24.226523 [ 3068 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:24.229379 [ 6609 ] {808d2845-6c80-498f-87c8-e7b91cb35aef} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 2 arguments: In scope SELECT toUUID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUUID([], []);) 2025.10.23 23:32:24.233217 [ 6609 ] {808d2845-6c80-498f-87c8-e7b91cb35aef} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'toUUID'. Expected 1 argument, got 2 arguments: In scope SELECT toUUID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:24.274537 [ 6609 ] {0fee38e2-acc8-47ca-8c3b-de2f13a8583c} executeQuery: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Array(Nothing): In scope SELECT toUUIDOrDefault([], []). (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUUIDOrDefault([], []);) 2025.10.23 23:32:24.281000 [ 6609 ] {0fee38e2-acc8-47ca-8c3b-de2f13a8583c} TCPHandler: Code: 36. DB::Exception: Default value type should be same as cast type. Expected UUID. Actual Array(Nothing): In scope SELECT toUUIDOrDefault([], []). (BAD_ARGUMENTS) 2025.10.23 23:32:24.329710 [ 6609 ] {63e8c84d-a267-4ed4-b0f3-c120859c4cd3} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUUIDOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUUIDOrNull([], []);) 2025.10.23 23:32:24.334329 [ 6609 ] {63e8c84d-a267-4ed4-b0f3-c120859c4cd3} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUUIDOrNull. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrNull([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:24.383915 [ 6609 ] {c9e8ca11-1e82-41ce-b4c7-e18894d2ea30} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUUIDOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUUIDOrZero([], []);) 2025.10.23 23:32:24.389182 [ 6609 ] {c9e8ca11-1e82-41ce-b4c7-e18894d2ea30} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of first argument of function toUUIDOrZero. Conversion functions with postfix 'OrZero' or 'OrNull' should take String argument: In scope SELECT toUUIDOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:24.411776 [ 3066 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:24.435703 [ 6609 ] {c25818bb-0cfe-4cef-b029-6a4e7270b3c3} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toUnixTimestamp'. Expected: String, got: Array(Nothing): In scope SELECT toUnixTimestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUnixTimestamp([], []);) 2025.10.23 23:32:24.439353 [ 6609 ] {c25818bb-0cfe-4cef-b029-6a4e7270b3c3} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 2nd argument 'timezone' to function 'toUnixTimestamp'. Expected: String, got: Array(Nothing): In scope SELECT toUnixTimestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:24.444875 [ 3621 ] {cb345540-1497-48e5-8249-826383329fcf} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:24.448266 [ 3621 ] {cb345540-1497-48e5-8249-826383329fcf} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:24.458766 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (14 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:24.509968 [ 3070 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:24.552983 [ 6609 ] {93abb85c-3de5-448d-a58b-8b1fe092b791} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUnixTimestamp64Micro([], []);) 2025.10.23 23:32:24.567296 [ 6609 ] {93abb85c-3de5-448d-a58b-8b1fe092b791} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Micro doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Micro([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:24.668203 [ 6609 ] {d99853e0-be3a-445c-9eb2-2323cdc2e167} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUnixTimestamp64Milli([], []);) 2025.10.23 23:32:24.679581 [ 6609 ] {d99853e0-be3a-445c-9eb2-2323cdc2e167} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Milli doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Milli([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:24.853670 [ 6609 ] {45c071de-40c1-4bca-887c-66009d5d95f8} executeQuery: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toUnixTimestamp64Nano([], []);) 2025.10.23 23:32:24.873382 [ 6609 ] {45c071de-40c1-4bca-887c-66009d5d95f8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toUnixTimestamp64Nano doesn't match: passed 2, should be 1: In scope SELECT toUnixTimestamp64Nano([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:24.984858 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:24.986382 [ 6609 ] {949beea6-fb99-4264-ae13-91742c4e0b19} executeQuery: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toValidUTF8([], []);) 2025.10.23 23:32:24.991483 [ 6609 ] {949beea6-fb99-4264-ae13-91742c4e0b19} TCPHandler: Code: 42. DB::Exception: Number of arguments for function toValidUTF8 doesn't match: passed 2, should be 1: In scope SELECT toValidUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:25.011580 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:25.097444 [ 6609 ] {6f066cc1-68ce-4c0a-a907-0887338a50eb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toWeek([], []);) 2025.10.23 23:32:25.117962 [ 6609 ] {6f066cc1-68ce-4c0a-a907-0887338a50eb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:25.163763 [ 6609 ] {ca3e2508-7716-42de-827f-ba8d898922de} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMM. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMM([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toYYYYMM([], []);) 2025.10.23 23:32:25.169149 [ 6609 ] {ca3e2508-7716-42de-827f-ba8d898922de} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMM. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMM([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:25.209658 [ 6609 ] {59039896-f354-469a-ac79-876f3f0b8efb} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMMDD. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDD([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toYYYYMMDD([], []);) 2025.10.23 23:32:25.212969 [ 6609 ] {59039896-f354-469a-ac79-876f3f0b8efb} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMMDD. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDD([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:25.228462 [ 3078 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:25.260046 [ 6609 ] {8b8d91f6-75f7-4439-be41-15f858075954} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMMDDhhmmss. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDDhhmmss([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toYYYYMMDDhhmmss([], []);) 2025.10.23 23:32:25.265494 [ 6609 ] {8b8d91f6-75f7-4439-be41-15f858075954} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYYYYMMDDhhmmss. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYYYYMMDDhhmmss([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:25.327907 [ 6609 ] {78011f0f-adae-4621-8d53-c2235e873959} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toYear([], []);) 2025.10.23 23:32:25.332942 [ 6609 ] {78011f0f-adae-4621-8d53-c2235e873959} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function toYear. Should be Date, Date32, DateTime or DateTime64: In scope SELECT toYear([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:25.381014 [ 6609 ] {7d9e1386-f934-4f8e-a807-93dedeb30e99} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toYearWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT toYearWeek([], []);) 2025.10.23 23:32:25.385731 [ 6609 ] {7d9e1386-f934-4f8e-a807-93dedeb30e99} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT toYearWeek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:25.414044 [ 3084 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:25.489246 [ 6609 ] {8db24b34-8d60-4dd2-8d9d-863205a42903} executeQuery: Code: 43. DB::Exception: Function toUTCTimestamp's 1st argument type must be datetime.: In scope SELECT to_utc_timestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT to_utc_timestamp([], []);) 2025.10.23 23:32:25.495584 [ 6609 ] {8db24b34-8d60-4dd2-8d9d-863205a42903} TCPHandler: Code: 43. DB::Exception: Function toUTCTimestamp's 1st argument type must be datetime.: In scope SELECT to_utc_timestamp([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:25.512339 [ 3086 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:25.541093 [ 6609 ] {0937dd01-8ca7-4a5d-aea1-bd2ac126e9c7} executeQuery: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT today([], []);) 2025.10.23 23:32:25.545265 [ 6609 ] {0937dd01-8ca7-4a5d-aea1-bd2ac126e9c7} TCPHandler: Code: 42. DB::Exception: Number of arguments for function today doesn't match: passed 2, should be 0: In scope SELECT today([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:25.586671 [ 6609 ] {fe3ca9bd-0c34-4d21-8479-592334b4d5eb} executeQuery: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tokens([], []);) 2025.10.23 23:32:25.598691 [ 6609 ] {fe3ca9bd-0c34-4d21-8479-592334b4d5eb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tokens doesn't match: passed 2, should be 1: In scope SELECT tokens([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:25.726592 [ 6609 ] {0ce88076-a69d-4bcb-a603-ff9c435b8bb2} executeQuery: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT topK([], []);) 2025.10.23 23:32:25.744927 [ 6609 ] {0ce88076-a69d-4bcb-a603-ff9c435b8bb2} TCPHandler: Code: 42. DB::Exception: Aggregate function topK requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:25.868387 [ 6609 ] {15fa610e-13e9-4224-9b09-e6d2fcc3d3ab} executeQuery: Code: 43. DB::Exception: The second argument for aggregate function 'topKWeighted' must have integer type. (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT topKWeighted([], []);) 2025.10.23 23:32:25.875335 [ 6609 ] {15fa610e-13e9-4224-9b09-e6d2fcc3d3ab} TCPHandler: Code: 43. DB::Exception: The second argument for aggregate function 'topKWeighted' must have integer type. (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:26.004392 [ 6609 ] {2bb1a58e-021b-401b-9ef8-540520e0a56e} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT topLevelDomain([], []);) 2025.10.23 23:32:26.008700 [ 6609 ] {2bb1a58e-021b-401b-9ef8-540520e0a56e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomain doesn't match: passed 2, should be 1: In scope SELECT topLevelDomain([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.042796 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:26.114950 [ 6609 ] {f70f137d-542c-4733-9eb3-4e5f92dc9a7e} executeQuery: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT topLevelDomainRFC([], []);) 2025.10.23 23:32:26.131931 [ 6609 ] {f70f137d-542c-4733-9eb3-4e5f92dc9a7e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function topLevelDomainRFC doesn't match: passed 2, should be 1: In scope SELECT topLevelDomainRFC([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.149273 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:26.230585 [ 3092 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:26.233244 [ 6609 ] {7051bda5-cf7a-4aa0-b29a-e6a52e18c68b} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT transactionID([], []);) 2025.10.23 23:32:26.251821 [ 6609 ] {7051bda5-cf7a-4aa0-b29a-e6a52e18c68b} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionID doesn't match: passed 2, should be 0: In scope SELECT transactionID([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.306176 [ 6609 ] {184aeb32-b8f5-4c58-b0ce-066d048b8318} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT transactionLatestSnapshot([], []);) 2025.10.23 23:32:26.310940 [ 6609 ] {184aeb32-b8f5-4c58-b0ce-066d048b8318} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionLatestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionLatestSnapshot([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.364818 [ 6609 ] {36d815f4-519a-49da-935f-85a8e3884506} executeQuery: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT transactionOldestSnapshot([], []);) 2025.10.23 23:32:26.369101 [ 6609 ] {36d815f4-519a-49da-935f-85a8e3884506} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transactionOldestSnapshot doesn't match: passed 2, should be 0: In scope SELECT transactionOldestSnapshot([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.416939 [ 6609 ] {d803718c-9a0d-4f3d-b75f-c559d671243f} executeQuery: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT transform([], []);) 2025.10.23 23:32:26.418237 [ 3099 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:26.421852 [ 6609 ] {d803718c-9a0d-4f3d-b75f-c559d671243f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function transform doesn't match: passed 2, should be 3 or 4: In scope SELECT transform([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.468860 [ 6609 ] {cd2553e3-a85d-4830-ac6c-726561b12f47} executeQuery: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT translate([], []);) 2025.10.23 23:32:26.472967 [ 6609 ] {cd2553e3-a85d-4830-ac6c-726561b12f47} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translate doesn't match: passed 2, should be 3: In scope SELECT translate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.514811 [ 3101 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:26.529324 [ 6609 ] {11962896-39b6-4458-926c-408b869779d3} executeQuery: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT translateUTF8([], []);) 2025.10.23 23:32:26.536340 [ 6609 ] {11962896-39b6-4458-926c-408b869779d3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function translateUTF8 doesn't match: passed 2, should be 3: In scope SELECT translateUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.600527 [ 6609 ] {7a1b195a-840d-47b4-9e4a-e99f2db790c6} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 2, should be 1: In scope SELECT trimBoth([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT trimBoth([], []);) 2025.10.23 23:32:26.605608 [ 6609 ] {7a1b195a-840d-47b4-9e4a-e99f2db790c6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimBoth doesn't match: passed 2, should be 1: In scope SELECT trimBoth([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.658535 [ 6609 ] {afd83300-fa10-4757-bd2a-4a56fcd0f9cb} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 2, should be 1: In scope SELECT trimLeft([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT trimLeft([], []);) 2025.10.23 23:32:26.663779 [ 6609 ] {afd83300-fa10-4757-bd2a-4a56fcd0f9cb} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimLeft doesn't match: passed 2, should be 1: In scope SELECT trimLeft([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.777117 [ 6609 ] {b1da1988-181e-48c9-b601-6bb893ca5744} executeQuery: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 2, should be 1: In scope SELECT trimRight([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT trimRight([], []);) 2025.10.23 23:32:26.791577 [ 6609 ] {b1da1988-181e-48c9-b601-6bb893ca5744} TCPHandler: Code: 42. DB::Exception: Number of arguments for function trimRight doesn't match: passed 2, should be 1: In scope SELECT trimRight([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:26.910109 [ 6609 ] {3efc3f69-f119-485f-bf1f-c73d9f863c61} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'trunc'. Expected: A number to round, got: Array(Nothing): In scope SELECT trunc([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT trunc([], []);) 2025.10.23 23:32:26.931937 [ 6609 ] {3efc3f69-f119-485f-bf1f-c73d9f863c61} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'trunc'. Expected: A number to round, got: Array(Nothing): In scope SELECT trunc([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:27.053433 [ 6609 ] {2821bed6-f99a-48a2-844b-470340ce5c18} executeQuery: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'trunc'. Expected: A number to round, got: Array(Nothing): In scope SELECT truncate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT truncate([], []);) 2025.10.23 23:32:27.061254 [ 6609 ] {2821bed6-f99a-48a2-844b-470340ce5c18} TCPHandler: Code: 43. DB::Exception: A value of illegal type was provided as 1st argument 'x' to function 'trunc'. Expected: A number to round, got: Array(Nothing): In scope SELECT truncate([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:27.158453 [ 6609 ] {96e1d5d3-05c1-4c78-892e-1f159d61253e} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tryBase58Decode([], []);) 2025.10.23 23:32:27.171406 [ 6609 ] {96e1d5d3-05c1-4c78-892e-1f159d61253e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase58Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase58Decode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:27.176096 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:27.233658 [ 3111 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:27.233852 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:27.263875 [ 6609 ] {75b50a81-d60e-47a3-bbdc-6dd7606cb1ca} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tryBase64Decode([], []);) 2025.10.23 23:32:27.267995 [ 6609 ] {75b50a81-d60e-47a3-bbdc-6dd7606cb1ca} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64Decode doesn't match: passed 2, should be 1: In scope SELECT tryBase64Decode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:27.354728 [ 6609 ] {8abebd57-6986-46b3-abfd-99f82ed20b29} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tryBase64URLDecode([], []);) 2025.10.23 23:32:27.358070 [ 6609 ] {8abebd57-6986-46b3-abfd-99f82ed20b29} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryBase64URLDecode doesn't match: passed 2, should be 1: In scope SELECT tryBase64URLDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:27.398940 [ 6609 ] {b7770ee5-c6e5-43ab-8e28-4597a1dbccf6} executeQuery: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT tryDecrypt([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tryDecrypt([], '[HIDDEN]')) 2025.10.23 23:32:27.405368 [ 6609 ] {b7770ee5-c6e5-43ab-8e28-4597a1dbccf6} TCPHandler: Code: 42. DB::Exception: An incorrect number of arguments was specified for function 'tryDecrypt'. Expected 3 mandatory arguments and 2 optional arguments, got 2 arguments: In scope SELECT tryDecrypt([], '[HIDDEN]'). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:27.420658 [ 3109 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:27.455170 [ 6609 ] {b9f7e6ae-68df-4931-a02a-2ce15e32cf79} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tryIdnaEncode([], []);) 2025.10.23 23:32:27.460032 [ 6609 ] {b9f7e6ae-68df-4931-a02a-2ce15e32cf79} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryIdnaEncode doesn't match: passed 2, should be 1: In scope SELECT tryIdnaEncode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:27.519661 [ 6609 ] {3a1f7ef2-945c-431a-b898-9a9381539782} executeQuery: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tryPunycodeDecode([], []);) 2025.10.23 23:32:27.525925 [ 6609 ] {3a1f7ef2-945c-431a-b898-9a9381539782} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tryPunycodeDecode doesn't match: passed 2, should be 1: In scope SELECT tryPunycodeDecode([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:27.552246 [ 3115 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:27.662184 [ 6609 ] {d927cac1-8a25-4d15-877c-49e3a2284480} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumble. Should be a date with time: In scope SELECT tumble([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tumble([], []);) 2025.10.23 23:32:27.672146 [ 6609 ] {d927cac1-8a25-4d15-877c-49e3a2284480} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumble. Should be a date with time: In scope SELECT tumble([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:27.742485 [ 6609 ] {99082c25-2670-442e-b230-282bd26f64ec} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumbleEnd. Should be a date with time: In scope SELECT tumbleEnd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tumbleEnd([], []);) 2025.10.23 23:32:27.747081 [ 6609 ] {99082c25-2670-442e-b230-282bd26f64ec} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumbleEnd. Should be a date with time: In scope SELECT tumbleEnd([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:27.853514 [ 6609 ] {e943f908-5526-4fab-b8f9-7b83ff9f747f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumbleStart. Should be a date with time: In scope SELECT tumbleStart([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tumbleStart([], []);) 2025.10.23 23:32:27.896989 [ 6609 ] {e943f908-5526-4fab-b8f9-7b83ff9f747f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function tumbleStart. Should be a date with time: In scope SELECT tumbleStart([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.160684 [ 3788 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:32:33: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:28.219087 [ 6609 ] {fa422a32-c763-4f6c-b544-036570226b6a} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleConcat([], []);) 2025.10.23 23:32:28.230552 [ 6609 ] {fa422a32-c763-4f6c-b544-036570226b6a} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument 1 of function tupleConcat: In scope SELECT tupleConcat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.236118 [ 3121 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:28.267814 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:28.287158 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:28.323196 [ 6609 ] {cb81e9e0-36f7-4775-b551-dbabe5574319} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleDivide should be tuple, got Array(Nothing): In scope SELECT tupleDivide([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleDivide([], []);) 2025.10.23 23:32:28.351725 [ 6609 ] {cb81e9e0-36f7-4775-b551-dbabe5574319} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleDivide should be tuple, got Array(Nothing): In scope SELECT tupleDivide([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.422960 [ 3123 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:28.451146 [ 6609 ] {f1d7f4fc-7028-47e2-afb1-8a1d9c65abc1} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleDivideByNumber should be tuple, got Array(Nothing): In scope SELECT tupleDivideByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleDivideByNumber([], []);) 2025.10.23 23:32:28.456020 [ 6609 ] {f1d7f4fc-7028-47e2-afb1-8a1d9c65abc1} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleDivideByNumber should be tuple, got Array(Nothing): In scope SELECT tupleDivideByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.546647 [ 6609 ] {4da8e3ac-660d-4eb1-a908-e34a8643da4d} executeQuery: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Array(Nothing): In scope SELECT tupleElement([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleElement([], []);) 2025.10.23 23:32:28.554113 [ 6609 ] {4da8e3ac-660d-4eb1-a908-e34a8643da4d} TCPHandler: Code: 43. DB::Exception: First argument for function tupleElement must be tuple or array of tuple. Actual Array(Nothing): In scope SELECT tupleElement([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.632598 [ 3125 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:28.688294 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:28.689667 [ 6609 ] {35731ffe-6466-4e96-ba85-761d2d01af9e} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleHammingDistance should be tuple, got Array(Nothing): In scope SELECT tupleHammingDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleHammingDistance([], []);) 2025.10.23 23:32:28.693526 [ 6609 ] {35731ffe-6466-4e96-ba85-761d2d01af9e} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleHammingDistance should be tuple, got Array(Nothing): In scope SELECT tupleHammingDistance([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.745348 [ 6609 ] {f1aa8076-cec0-47d5-a859-aad4bea43285} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleIntDiv should be tuple, got Array(Nothing): In scope SELECT tupleIntDiv([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleIntDiv([], []);) 2025.10.23 23:32:28.759651 [ 6609 ] {f1aa8076-cec0-47d5-a859-aad4bea43285} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleIntDiv should be tuple, got Array(Nothing): In scope SELECT tupleIntDiv([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.813657 [ 6609 ] {17cb27cc-dfab-4ca3-9eab-0d7c115fea5d} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleIntDivByNumber should be tuple, got Array(Nothing): In scope SELECT tupleIntDivByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleIntDivByNumber([], []);) 2025.10.23 23:32:28.818437 [ 6609 ] {17cb27cc-dfab-4ca3-9eab-0d7c115fea5d} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleIntDivByNumber should be tuple, got Array(Nothing): In scope SELECT tupleIntDivByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.866031 [ 6609 ] {304a7769-c4e6-4f18-ba3a-85cd2ee01649} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleIntDivOrZero should be tuple, got Array(Nothing): In scope SELECT tupleIntDivOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleIntDivOrZero([], []);) 2025.10.23 23:32:28.873222 [ 6609 ] {304a7769-c4e6-4f18-ba3a-85cd2ee01649} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleIntDivOrZero should be tuple, got Array(Nothing): In scope SELECT tupleIntDivOrZero([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:28.997012 [ 6609 ] {2b16b8b0-c5f9-4beb-81a4-65c5a0f414c4} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleIntDivOrZeroByNumber should be tuple, got Array(Nothing): In scope SELECT tupleIntDivOrZeroByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleIntDivOrZeroByNumber([], []);) 2025.10.23 23:32:29.011256 [ 6609 ] {2b16b8b0-c5f9-4beb-81a4-65c5a0f414c4} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleIntDivOrZeroByNumber should be tuple, got Array(Nothing): In scope SELECT tupleIntDivOrZeroByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:29.137147 [ 6609 ] {6c52b396-d5b4-4220-826e-df922cc5f45a} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleMinus should be tuple, got Array(Nothing): In scope SELECT tupleMinus([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleMinus([], []);) 2025.10.23 23:32:29.150293 [ 6609 ] {6c52b396-d5b4-4220-826e-df922cc5f45a} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleMinus should be tuple, got Array(Nothing): In scope SELECT tupleMinus([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:29.238660 [ 3133 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:29.277759 [ 6609 ] {12be77e6-4a40-4373-b718-96a56654355b} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleModulo should be tuple, got Array(Nothing): In scope SELECT tupleModulo([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleModulo([], []);) 2025.10.23 23:32:29.281064 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:29.283362 [ 6609 ] {12be77e6-4a40-4373-b718-96a56654355b} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleModulo should be tuple, got Array(Nothing): In scope SELECT tupleModulo([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:29.303391 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:29.400078 [ 6609 ] {da94ec48-3d5f-4018-90eb-d81d9e174e71} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleModuloByNumber should be tuple, got Array(Nothing): In scope SELECT tupleModuloByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleModuloByNumber([], []);) 2025.10.23 23:32:29.407396 [ 6609 ] {da94ec48-3d5f-4018-90eb-d81d9e174e71} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleModuloByNumber should be tuple, got Array(Nothing): In scope SELECT tupleModuloByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:29.424974 [ 3142 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:29.476530 [ 6609 ] {8b8eaeb3-c73a-45fb-b452-02cc0e421987} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleMultiply should be tuple, got Array(Nothing): In scope SELECT tupleMultiply([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleMultiply([], []);) 2025.10.23 23:32:29.480593 [ 6609 ] {8b8eaeb3-c73a-45fb-b452-02cc0e421987} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleMultiply should be tuple, got Array(Nothing): In scope SELECT tupleMultiply([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:29.533734 [ 6609 ] {cca031ba-331a-47c5-b14b-a037f91c941d} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleMultiplyByNumber should be tuple, got Array(Nothing): In scope SELECT tupleMultiplyByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleMultiplyByNumber([], []);) 2025.10.23 23:32:29.542463 [ 6609 ] {cca031ba-331a-47c5-b14b-a037f91c941d} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleMultiplyByNumber should be tuple, got Array(Nothing): In scope SELECT tupleMultiplyByNumber([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:29.593939 [ 6609 ] {f0b53723-5d10-4498-aa2d-162399eef720} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleNames([], []);) 2025.10.23 23:32:29.599112 [ 6609 ] {f0b53723-5d10-4498-aa2d-162399eef720} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNames doesn't match: passed 2, should be 1: In scope SELECT tupleNames([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:29.634824 [ 3144 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:29.650291 [ 6609 ] {28f4e614-33ee-490e-9784-7034b7283fbc} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleNegate([], []);) 2025.10.23 23:32:29.654539 [ 6609 ] {28f4e614-33ee-490e-9784-7034b7283fbc} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleNegate doesn't match: passed 2, should be 1: In scope SELECT tupleNegate([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:29.694451 [ 3621 ] {7328d1d9-9f8e-42ef-bf1e-6ddf0f63d4dd} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:29.700040 [ 3621 ] {7328d1d9-9f8e-42ef-bf1e-6ddf0f63d4dd} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:29.712924 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (15 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:29.714555 [ 6609 ] {7617eb77-b349-454a-9060-22ac6dcdbd9a} executeQuery: Code: 43. DB::Exception: Argument 0 of function tuplePlus should be tuple, got Array(Nothing): In scope SELECT tuplePlus([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tuplePlus([], []);) 2025.10.23 23:32:29.719740 [ 6609 ] {7617eb77-b349-454a-9060-22ac6dcdbd9a} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tuplePlus should be tuple, got Array(Nothing): In scope SELECT tuplePlus([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:29.784351 [ 6609 ] {cdfb0e82-1a31-4422-8c6e-0c4d765facfd} executeQuery: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT tupleToNameValuePairs([], []);) 2025.10.23 23:32:29.813589 [ 6609 ] {cdfb0e82-1a31-4422-8c6e-0c4d765facfd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function tupleToNameValuePairs doesn't match: passed 2, should be 1: In scope SELECT tupleToNameValuePairs([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:29.947919 [ 6609 ] {406e498d-36e5-4a99-aeab-971bf293548d} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT ucase([], []);) 2025.10.23 23:32:29.956230 [ 6609 ] {406e498d-36e5-4a99-aeab-971bf293548d} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT ucase([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:30.042309 [ 6609 ] {1aa91aa3-b775-4c98-a62b-9dc7eaaf30a3} executeQuery: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT unbin([], []);) 2025.10.23 23:32:30.053461 [ 6609 ] {1aa91aa3-b775-4c98-a62b-9dc7eaaf30a3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unbin doesn't match: passed 2, should be 1: In scope SELECT unbin([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:30.183338 [ 6609 ] {afcfdcd7-33ed-41f4-969c-dad2d8cd1eaa} executeQuery: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT unhex([], []);) 2025.10.23 23:32:30.188382 [ 6609 ] {afcfdcd7-33ed-41f4-969c-dad2d8cd1eaa} TCPHandler: Code: 42. DB::Exception: Number of arguments for function unhex doesn't match: passed 2, should be 1: In scope SELECT unhex([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:30.240810 [ 3158 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:30.308428 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:30.376180 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:30.426981 [ 3163 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:30.636644 [ 3170 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:30.640859 [ 6609 ] {7cf850d0-048c-470d-a966-ec004ae4c2d3} executeQuery: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT uniqCombined64([], []);) 2025.10.23 23:32:30.643569 [ 6609 ] {7cf850d0-048c-470d-a966-ec004ae4c2d3} TCPHandler: Code: 241. DB::Exception: Memory tracker (for query): fault injected. Would use 0.00 B (attempt to allocate chunk of 0 bytes), maximum: 9.31 GiB: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) 2025.10.23 23:32:31.069087 [ 6609 ] {a51c7514-3634-4949-ad92-4a5d8c747f8c} executeQuery: Code: 43. DB::Exception: First argument for function uniqThetaIntersect must be a uniqTheta but it has type Array(Nothing): In scope SELECT uniqThetaIntersect([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT uniqThetaIntersect([], []);) 2025.10.23 23:32:31.084642 [ 6609 ] {a51c7514-3634-4949-ad92-4a5d8c747f8c} TCPHandler: Code: 43. DB::Exception: First argument for function uniqThetaIntersect must be a uniqTheta but it has type Array(Nothing): In scope SELECT uniqThetaIntersect([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:31.242736 [ 3180 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:31.272896 [ 6609 ] {506a1b01-0eca-43a4-8870-b1329020303c} executeQuery: Code: 43. DB::Exception: First argument for function uniqThetaNot must be a uniqTheta but it has type Array(Nothing): In scope SELECT uniqThetaNot([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT uniqThetaNot([], []);) 2025.10.23 23:32:31.283116 [ 6609 ] {506a1b01-0eca-43a4-8870-b1329020303c} TCPHandler: Code: 43. DB::Exception: First argument for function uniqThetaNot must be a uniqTheta but it has type Array(Nothing): In scope SELECT uniqThetaNot([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:31.326826 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:31.386503 [ 6609 ] {ce60c815-ea88-4685-b77d-6fee4f2040b2} executeQuery: Code: 43. DB::Exception: First argument for function uniqThetaUnion must be a uniqTheta but it has type Array(Nothing): In scope SELECT uniqThetaUnion([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT uniqThetaUnion([], []);) 2025.10.23 23:32:31.392709 [ 6609 ] {ce60c815-ea88-4685-b77d-6fee4f2040b2} TCPHandler: Code: 43. DB::Exception: First argument for function uniqThetaUnion must be a uniqTheta but it has type Array(Nothing): In scope SELECT uniqThetaUnion([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:31.422458 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:31.429272 [ 3181 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:31.575406 [ 6609 ] {3ee36dde-733e-42b0-a0a3-595a729f66fd} executeQuery: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT upper([], []);) 2025.10.23 23:32:31.589686 [ 6609 ] {3ee36dde-733e-42b0-a0a3-595a729f66fd} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upper doesn't match: passed 2, should be 1: In scope SELECT upper([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:31.638579 [ 3175 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:31.645517 [ 6609 ] {b08a038e-1e50-4d45-a20a-dd1130e46da8} executeQuery: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT upperUTF8([], []);) 2025.10.23 23:32:31.653110 [ 6609 ] {b08a038e-1e50-4d45-a20a-dd1130e46da8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function upperUTF8 doesn't match: passed 2, should be 1: In scope SELECT upperUTF8([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:31.795493 [ 6609 ] {6d5d49bf-d48d-4c64-a02b-c0548e6feb26} executeQuery: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT uptime([], []);) 2025.10.23 23:32:31.805634 [ 6609 ] {6d5d49bf-d48d-4c64-a02b-c0548e6feb26} TCPHandler: Code: 42. DB::Exception: Number of arguments for function uptime doesn't match: passed 2, should be 0: In scope SELECT uptime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:31.844757 [ 6609 ] {f4b62c54-e50e-4cb3-90d5-8bf8905cb7e8} executeQuery: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT user([], []);) 2025.10.23 23:32:31.850492 [ 6609 ] {f4b62c54-e50e-4cb3-90d5-8bf8905cb7e8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function currentUser doesn't match: passed 2, should be 0: In scope SELECT user([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:31.900353 [ 6609 ] {250c35e6-b21c-4619-a8c3-3f5bc06c0586} executeQuery: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 2.: In scope SELECT validateNestedArraySizes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT validateNestedArraySizes([], []);) 2025.10.23 23:32:31.905799 [ 6609 ] {250c35e6-b21c-4619-a8c3-3f5bc06c0586} TCPHandler: Code: 42. DB::Exception: Function validateNestedArraySizes needs more than two arguments; passed 2.: In scope SELECT validateNestedArraySizes([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:31.970615 [ 6609 ] {c25d551f-7bb2-47f5-a33b-bc4e73428f7e} executeQuery: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT varPop([], []);) 2025.10.23 23:32:31.975304 [ 6609 ] {c25d551f-7bb2-47f5-a33b-bc4e73428f7e} TCPHandler: Code: 42. DB::Exception: Aggregate function varPop requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:32.149121 [ 6609 ] {068c7438-f9db-4d24-9ec8-f136597930d9} executeQuery: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT varPopStable([], []);) 2025.10.23 23:32:32.166396 [ 6609 ] {068c7438-f9db-4d24-9ec8-f136597930d9} TCPHandler: Code: 42. DB::Exception: Aggregate function varPopStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:32.244850 [ 3166 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:32.268425 [ 6609 ] {574e6725-5f4d-4d85-b581-1f3d30640d2d} executeQuery: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT varSamp([], []);) 2025.10.23 23:32:32.281902 [ 6609 ] {574e6725-5f4d-4d85-b581-1f3d30640d2d} TCPHandler: Code: 42. DB::Exception: Aggregate function varSamp requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:32.370849 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:32.371564 [ 6609 ] {976ef56e-a47e-479e-8a9f-d617c74cc9d1} executeQuery: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT varSampStable([], []);) 2025.10.23 23:32:32.377922 [ 6609 ] {976ef56e-a47e-479e-8a9f-d617c74cc9d1} TCPHandler: Code: 42. DB::Exception: Aggregate function varSampStable requires single argument. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:32.433119 [ 3193 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:32.483680 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:32.513846 [ 6609 ] {194cc863-1bd0-4cfb-bba8-934f91df4ebb} executeQuery: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Array(Nothing): In scope SELECT variantElement([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT variantElement([], []);) 2025.10.23 23:32:32.526615 [ 6609 ] {194cc863-1bd0-4cfb-bba8-934f91df4ebb} TCPHandler: Code: 43. DB::Exception: First argument for function variantElement must be Variant or Array of Variant. Actual Array(Nothing): In scope SELECT variantElement([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:32.596647 [ 6609 ] {c2403eba-4c6c-4d18-a884-7a588283c594} executeQuery: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT variantType([], []);) 2025.10.23 23:32:32.604236 [ 6609 ] {c2403eba-4c6c-4d18-a884-7a588283c594} TCPHandler: Code: 42. DB::Exception: Number of arguments for function variantType doesn't match: passed 2, should be 1: In scope SELECT variantType([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:32.640749 [ 3200 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:32.651752 [ 6609 ] {6c095976-dd03-4da8-bf85-699499916061} executeQuery: Code: 43. DB::Exception: Argument 0 of function tupleMinus should be tuple, got Array(Nothing): In scope SELECT vectorDifference([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT vectorDifference([], []);) 2025.10.23 23:32:32.655591 [ 6609 ] {6c095976-dd03-4da8-bf85-699499916061} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tupleMinus should be tuple, got Array(Nothing): In scope SELECT vectorDifference([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:32.698858 [ 6609 ] {df92bd8f-0e23-4ac3-a10d-3983fa416122} executeQuery: Code: 43. DB::Exception: Argument 0 of function tuplePlus should be tuple, got Array(Nothing): In scope SELECT vectorSum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT vectorSum([], []);) 2025.10.23 23:32:32.794410 [ 6609 ] {df92bd8f-0e23-4ac3-a10d-3983fa416122} TCPHandler: Code: 43. DB::Exception: Argument 0 of function tuplePlus should be tuple, got Array(Nothing): In scope SELECT vectorSum([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:32.855751 [ 6609 ] {19ceb85a-6c4b-41bd-9bbc-88ba74bb40b4} executeQuery: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT version([], []);) 2025.10.23 23:32:32.860352 [ 6609 ] {19ceb85a-6c4b-41bd-9bbc-88ba74bb40b4} TCPHandler: Code: 42. DB::Exception: Number of arguments for function version doesn't match: passed 2, should be 0: In scope SELECT version([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:32.919876 [ 6609 ] {273c123f-4b28-4c5d-8060-be3da458398e} executeQuery: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT visibleWidth([], []);) 2025.10.23 23:32:32.923897 [ 6609 ] {273c123f-4b28-4c5d-8060-be3da458398e} TCPHandler: Code: 42. DB::Exception: Number of arguments for function visibleWidth doesn't match: passed 2, should be 1: In scope SELECT visibleWidth([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:33.066535 [ 6609 ] {b4180b23-7710-4584-b06f-adcee1fa3024} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractBool: In scope SELECT visitParamExtractBool([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT visitParamExtractBool([], []);) 2025.10.23 23:32:33.079255 [ 6609 ] {b4180b23-7710-4584-b06f-adcee1fa3024} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractBool: In scope SELECT visitParamExtractBool([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:33.254295 [ 3207 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:33.303188 [ 6609 ] {05a5837a-f5ca-4a90-a3c2-206e8776d2b4} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractFloat: In scope SELECT visitParamExtractFloat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT visitParamExtractFloat([], []);) 2025.10.23 23:32:33.306462 [ 6609 ] {05a5837a-f5ca-4a90-a3c2-206e8776d2b4} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractFloat: In scope SELECT visitParamExtractFloat([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:33.413605 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:33.435079 [ 3209 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:33.447023 [ 6609 ] {09d22c28-c2d8-407d-8718-036cad7f58cd} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractInt: In scope SELECT visitParamExtractInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT visitParamExtractInt([], []);) 2025.10.23 23:32:33.457070 [ 6609 ] {09d22c28-c2d8-407d-8718-036cad7f58cd} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractInt: In scope SELECT visitParamExtractInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:33.526643 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:33.570891 [ 6609 ] {8b40b417-a700-4c7a-bb57-c26e262db4c5} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractRaw: In scope SELECT visitParamExtractRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT visitParamExtractRaw([], []);) 2025.10.23 23:32:33.576685 [ 6609 ] {8b40b417-a700-4c7a-bb57-c26e262db4c5} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractRaw: In scope SELECT visitParamExtractRaw([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:33.634124 [ 6609 ] {8fb2db2b-15ed-464f-be22-e62fecf8417f} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractString: In scope SELECT visitParamExtractString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT visitParamExtractString([], []);) 2025.10.23 23:32:33.637721 [ 6609 ] {8fb2db2b-15ed-464f-be22-e62fecf8417f} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractString: In scope SELECT visitParamExtractString([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:33.642942 [ 3210 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:33.719357 [ 6609 ] {e04891c7-91da-4606-97d6-d3f0b02e2a51} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractUInt: In scope SELECT visitParamExtractUInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT visitParamExtractUInt([], []);) 2025.10.23 23:32:33.725124 [ 6609 ] {e04891c7-91da-4606-97d6-d3f0b02e2a51} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONExtractUInt: In scope SELECT visitParamExtractUInt([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:33.740619 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:33.870646 [ 6609 ] {d5516be3-db0a-4016-9dc6-1d7a00fd36c2} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONHas: In scope SELECT visitParamHas([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT visitParamHas([], []);) 2025.10.23 23:32:33.878000 [ 6609 ] {d5516be3-db0a-4016-9dc6-1d7a00fd36c2} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function simpleJSONHas: In scope SELECT visitParamHas([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:33.920489 [ 6609 ] {d9563b9a-bd9a-498c-a6f5-2ec90bc98787} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT week([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT week([], []);) 2025.10.23 23:32:33.925087 [ 6609 ] {d9563b9a-bd9a-498c-a6f5-2ec90bc98787} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT week([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:33.971849 [ 6609 ] {cfdd7914-af6d-4dd9-bc33-81fd6434a458} executeQuery: Code: 36. DB::Exception: Aggregate function welchTTest only supports numerical types. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT welchTTest([], []);) 2025.10.23 23:32:33.976228 [ 6609 ] {cfdd7914-af6d-4dd9-bc33-81fd6434a458} TCPHandler: Code: 36. DB::Exception: Aggregate function welchTTest only supports numerical types. (BAD_ARGUMENTS) 2025.10.23 23:32:34.022088 [ 6609 ] {951305ff-ccb8-4ab2-b1b7-171661211c4f} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT widthBucket([], []);) 2025.10.23 23:32:34.026636 [ 6609 ] {951305ff-ccb8-4ab2-b1b7-171661211c4f} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT widthBucket([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:34.115281 [ 6609 ] {94ee79eb-67db-4c08-857f-e2cfb04e34c3} executeQuery: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT width_bucket([], []);) 2025.10.23 23:32:34.119452 [ 6609 ] {94ee79eb-67db-4c08-857f-e2cfb04e34c3} TCPHandler: Code: 42. DB::Exception: Number of arguments for function widthBucket doesn't match: passed 2, should be 4: In scope SELECT width_bucket([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:34.256375 [ 3223 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:34.286478 [ 6609 ] {68cb9a44-58e7-4c9b-8e34-ea919d9a0a4f} executeQuery: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT windowFunnel([], []);) 2025.10.23 23:32:34.302229 [ 6609 ] {68cb9a44-58e7-4c9b-8e34-ea919d9a0a4f} TCPHandler: Code: 42. DB::Exception: Aggregate function windowFunnel requires at least one parameter: , [option, [option, ...]]. (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:34.430342 [ 6609 ] {a2a4a0b0-b241-4109-b28f-dd2994dd78f1} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function windowID. Should be a date with time: In scope SELECT windowID([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT windowID([], []);) 2025.10.23 23:32:34.436065 [ 6609 ] {a2a4a0b0-b241-4109-b28f-dd2994dd78f1} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of argument of function windowID. Should be a date with time: In scope SELECT windowID([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:34.437153 [ 3236 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:34.525395 [ 6609 ] {16684dda-eeb5-4ffc-a529-f6ed74f0bed8} executeQuery: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wkt([], []);) 2025.10.23 23:32:34.536046 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:34.536094 [ 6609 ] {16684dda-eeb5-4ffc-a529-f6ed74f0bed8} TCPHandler: Code: 42. DB::Exception: Number of arguments for function wkt doesn't match: passed 2, should be 1: In scope SELECT wkt([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:34.644703 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:34.645391 [ 3233 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:34.689503 [ 6609 ] {a0705857-5a5f-4658-88e7-1cad90a1e950} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nothing): In scope SELECT wordShingleMinHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleMinHash([], []);) 2025.10.23 23:32:34.697143 [ 6609 ] {a0705857-5a5f-4658-88e7-1cad90a1e950} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHash must be String, got Array(Nothing): In scope SELECT wordShingleMinHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:34.776040 [ 6609 ] {d4938429-dc49-40ff-aad5-0411acc2eed6} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArg([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleMinHashArg([], []);) 2025.10.23 23:32:34.780576 [ 6609 ] {d4938429-dc49-40ff-aad5-0411acc2eed6} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArg must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArg([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:34.850866 [ 6609 ] {9f83c868-f263-4646-a6c0-6f7ca7e0aba4} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleMinHashArgCaseInsensitive([], []);) 2025.10.23 23:32:34.854764 [ 6609 ] {9f83c868-f263-4646-a6c0-6f7ca7e0aba4} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:34.905832 [ 6609 ] {4146c39d-1efb-49a7-9aeb-9f384b3fb511} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleMinHashArgCaseInsensitiveUTF8([], []);) 2025.10.23 23:32:34.916963 [ 6609 ] {4146c39d-1efb-49a7-9aeb-9f384b3fb511} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:35.002864 [ 6609 ] {8793e6e4-b4b1-478b-b9ff-7da0763c42d2} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleMinHashArgUTF8([], []);) 2025.10.23 23:32:35.007714 [ 6609 ] {8793e6e4-b4b1-478b-b9ff-7da0763c42d2} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashArgUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashArgUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:35.041412 [ 3621 ] {d7a25f3e-4281-444c-a6b5-24a692dda09a} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:35.045397 [ 3621 ] {d7a25f3e-4281-444c-a6b5-24a692dda09a} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:35.071618 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (16 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:35.074617 [ 6609 ] {357b039b-3cee-4a6e-acfc-cde5ee1defbd} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleMinHashCaseInsensitive([], []);) 2025.10.23 23:32:35.080170 [ 6609 ] {357b039b-3cee-4a6e-acfc-cde5ee1defbd} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:35.177850 [ 6609 ] {f0e4d0f6-9ac5-4b05-9d01-7c6799b8db3e} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleMinHashCaseInsensitiveUTF8([], []);) 2025.10.23 23:32:35.184055 [ 6609 ] {f0e4d0f6-9ac5-4b05-9d01-7c6799b8db3e} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:35.263883 [ 3250 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:35.311667 [ 6609 ] {e0bc7207-71a6-44d1-8eb9-37b662b5bd2d} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleMinHashUTF8([], []);) 2025.10.23 23:32:35.322626 [ 6609 ] {e0bc7207-71a6-44d1-8eb9-37b662b5bd2d} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleMinHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleMinHashUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:35.482051 [ 3253 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:35.533435 [ 6609 ] {359bbcf1-4f86-427d-ae5f-56b861bfb58f} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nothing): In scope SELECT wordShingleSimHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleSimHash([], []);) 2025.10.23 23:32:35.536811 [ 6609 ] {359bbcf1-4f86-427d-ae5f-56b861bfb58f} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHash must be String, got Array(Nothing): In scope SELECT wordShingleSimHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:35.599636 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:35.648111 [ 6609 ] {254cb9ba-cbc2-4d6c-9716-a8e8d06f0fad} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleSimHashCaseInsensitive([], []);) 2025.10.23 23:32:35.648554 [ 3259 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:35.666100 [ 6609 ] {254cb9ba-cbc2-4d6c-9716-a8e8d06f0fad} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitive must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitive([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:35.732144 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:35.805286 [ 6609 ] {bc9ffb35-f8b0-497f-b9bf-8ce683d3e383} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleSimHashCaseInsensitiveUTF8([], []);) 2025.10.23 23:32:35.820489 [ 6609 ] {bc9ffb35-f8b0-497f-b9bf-8ce683d3e383} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashCaseInsensitiveUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashCaseInsensitiveUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:35.870284 [ 6609 ] {f87c1978-b3bd-4641-9cc3-6feda68cfad3} executeQuery: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT wordShingleSimHashUTF8([], []);) 2025.10.23 23:32:35.875367 [ 6609 ] {f87c1978-b3bd-4641-9cc3-6feda68cfad3} TCPHandler: Code: 43. DB::Exception: First argument of function wordShingleSimHashUTF8 must be String, got Array(Nothing): In scope SELECT wordShingleSimHashUTF8([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:36.089700 [ 6609 ] {21055842-ef74-4f3e-b72c-848c4c264253} executeQuery: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function xor: In scope SELECT xor([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT xor([], []);) 2025.10.23 23:32:36.094948 [ 6609 ] {21055842-ef74-4f3e-b72c-848c4c264253} TCPHandler: Code: 43. DB::Exception: Illegal type (Array(Nothing)) of 1 argument of function xor: In scope SELECT xor([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:36.266290 [ 3265 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:36.484217 [ 3269 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:36.645954 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:36.651449 [ 3277 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:36.762104 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:36.800780 [ 6609 ] {f2db5ab8-6b35-4800-8a3d-99b030fed506} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function kostikConsistentHash: In scope SELECT yandexConsistentHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT yandexConsistentHash([], []);) 2025.10.23 23:32:36.812671 [ 6609 ] {f2db5ab8-6b35-4800-8a3d-99b030fed506} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of the first argument of function kostikConsistentHash: In scope SELECT yandexConsistentHash([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:36.905331 [ 6609 ] {721e3697-3bd7-40bf-a7b8-c12aadfab811} executeQuery: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT yearweek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT yearweek([], []);) 2025.10.23 23:32:36.911063 [ 6609 ] {721e3697-3bd7-40bf-a7b8-c12aadfab811} TCPHandler: Code: 43. DB::Exception: Illegal type Array(Nothing) of 1st argument of function toYearWeek. Must be Date, Date32, DateTime or DateTime64.: In scope SELECT yearweek([], []). (ILLEGAL_TYPE_OF_ARGUMENT) 2025.10.23 23:32:36.956842 [ 6609 ] {49b16f1b-dd18-47d6-8166-aaf2d86bbbbf} executeQuery: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT yesterday([], []);) 2025.10.23 23:32:36.960828 [ 6609 ] {49b16f1b-dd18-47d6-8166-aaf2d86bbbbf} TCPHandler: Code: 42. DB::Exception: Number of arguments for function yesterday doesn't match: passed 2, should be 0: In scope SELECT yesterday([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:37.040253 [ 6609 ] {fceac9af-7914-4b1f-9045-79a34176edc6} executeQuery: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56768) (comment: 00534_functions_bad_arguments9.sh) (in query: SELECT zookeeperSessionUptime([], []);) 2025.10.23 23:32:37.046689 [ 6609 ] {fceac9af-7914-4b1f-9045-79a34176edc6} TCPHandler: Code: 42. DB::Exception: Number of arguments for function zookeeperSessionUptime doesn't match: passed 2, should be 0: In scope SELECT zookeeperSessionUptime([], []). (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) 2025.10.23 23:32:37.268641 [ 3270 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:37.486386 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:37.657252 [ 2796 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:37.702226 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:37.857686 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:38.271386 [ 2790 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:38.488771 [ 2784 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:38.660019 [ 2782 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:38.850348 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:38.867628 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:38.929898 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:39.273481 [ 2817 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:39.491360 [ 2822 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:39.662347 [ 2827 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:39.920256 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:39.943755 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:40.275762 [ 2836 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:40.384906 [ 3621 ] {60d0f3fd-9ba7-4c7a-af78-fa0f32334016} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:40.396194 [ 3621 ] {60d0f3fd-9ba7-4c7a-af78-fa0f32334016} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:40.418473 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (17 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:40.493957 [ 2828 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:40.664766 [ 2841 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:40.794625 [ 4294 ] {128a237c-d433-4a74-8c5a-9663986c7ebd} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53888) (comment: 01271_http_code_parse_error.sh) (in query: CREATE TABLE test (f1 String, f2 String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:40.806752 [ 4294 ] {128a237c-d433-4a74-8c5a-9663986c7ebd} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:40.978472 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:40.982782 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:41.237025 [ 8268 ] {1fade9e8-05cc-4710-9011-7c0633c55beb} executeQuery: Code: 60. DB::Exception: Table test_11.test does not exist. Maybe you meant test_11.test1?. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:53136) (comment: 01271_http_code_parse_error.sh) (in query: insert into test (f1, f2) format TSV ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000002935d1b4 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44816 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:41.241315 [ 8268 ] {1fade9e8-05cc-4710-9011-7c0633c55beb} DynamicQueryHandler: Code: 60. DB::Exception: Table test_11.test does not exist. Maybe you meant test_11.test1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000002935d1b4 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44816 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:41.278841 [ 2850 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:41.496643 [ 2848 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:41.672263 [ 2853 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:41.957379 [ 4294 ] {563d2d1a-e05f-4c57-9f2d-83e93a1f22c9} executeQuery: Code: 60. DB::Exception: Table test_11.test does not exist. Maybe you meant test_11.test1?. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53916) (comment: 01271_http_code_parse_error.sh) (in query: DROP TABLE test), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c626c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd4b1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:32:41.970067 [ 4294 ] {563d2d1a-e05f-4c57-9f2d-83e93a1f22c9} TCPHandler: Code: 60. DB::Exception: Table test_11.test does not exist. Maybe you meant test_11.test1?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c626c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd4b1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:32:42.006726 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:42.031976 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:42.281173 [ 2870 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:42.498912 [ 2873 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:42.674873 [ 2877 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:43.081700 [ 3620 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:32:48: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:43.133521 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:43.246116 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:43.283659 [ 2884 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:43.501446 [ 2894 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:43.677346 [ 2893 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:44.029508 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:44.223404 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:44.285750 [ 2908 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:44.401287 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:44.503633 [ 2910 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:44.679689 [ 2911 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:44.945799 [ 4294 ] {da773aa7-10d4-41cf-9c51-707780ff5598} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53500) (comment: 01273_arrow_nullable_arrays_load.sh) (in query: CREATE TABLE arrow_nullable_arrays (arr1 Array(Nullable(UInt32)), arr2 Array(Nullable(String)), arr3 Array(Nullable(Float32))) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:44.949005 [ 4294 ] {da773aa7-10d4-41cf-9c51-707780ff5598} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:45.288095 [ 2926 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:45.295253 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:45.505731 [ 2930 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:45.530078 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:45.681831 [ 2935 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:45.707742 [ 3621 ] {0fa4c57c-04db-43ff-bd34-f30efb113ea0} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:45.709455 [ 4147 ] {ab04d0d4-3a51-4bab-bab0-8911f127de04} executeQuery: Code: 60. DB::Exception: Table test_11.arrow_nullable_arrays does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53528) (comment: 01273_arrow_nullable_arrays_load.sh) (in query: INSERT INTO arrow_nullable_arrays VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:45.712953 [ 3621 ] {0fa4c57c-04db-43ff-bd34-f30efb113ea0} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:45.715621 [ 4147 ] {ab04d0d4-3a51-4bab-bab0-8911f127de04} TCPHandler: Code: 60. DB::Exception: Table test_11.arrow_nullable_arrays does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:45.746317 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (18 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:46.290280 [ 2944 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:46.336996 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:46.508138 [ 2945 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:46.585947 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:46.597476 [ 4294 ] {27a4f95f-4ba8-47a2-8947-0f3c9205236e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'arrow_nullable_arrays' in scope SELECT * FROM arrow_nullable_arrays. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53530) (comment: 01273_arrow_nullable_arrays_load.sh) (in query: SELECT * FROM arrow_nullable_arrays FORMAT Arrow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:46.620882 [ 4294 ] {27a4f95f-4ba8-47a2-8947-0f3c9205236e} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'arrow_nullable_arrays' in scope SELECT * FROM arrow_nullable_arrays. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:46.685472 [ 2954 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:47.292391 [ 2965 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:47.434345 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:47.522917 [ 2976 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:47.648151 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:47.688998 [ 2977 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:47.869579 [ 4294 ] {9f1525e2-275c-4416-bf82-e86bc110703c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'arrow_nullable_arrays' in scope SELECT * FROM arrow_nullable_arrays. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53592) (comment: 01273_arrow_nullable_arrays_load.sh) (in query: SELECT * FROM arrow_nullable_arrays), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:47.873764 [ 4294 ] {9f1525e2-275c-4416-bf82-e86bc110703c} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'arrow_nullable_arrays' in scope SELECT * FROM arrow_nullable_arrays. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:48.294865 [ 2988 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:48.474677 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:48.525541 [ 2993 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:48.669234 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:48.691493 [ 2996 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:48.715607 [ 4147 ] {22f08e25-4b7d-4601-9b96-ff36ecc5df41} executeQuery: Code: 60. DB::Exception: Table test_11.arrow_nullable_arrays does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53600) (comment: 01273_arrow_nullable_arrays_load.sh) (in query: DROP TABLE arrow_nullable_arrays), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c626c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd4b1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:32:48.721896 [ 4147 ] {22f08e25-4b7d-4601-9b96-ff36ecc5df41} TCPHandler: Code: 60. DB::Exception: Table test_11.arrow_nullable_arrays does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c626c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd4b1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:32:49.135778 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:49.297279 [ 3006 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:49.527534 [ 3012 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:49.558326 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:49.693894 [ 2998 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:49.793639 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:50.301738 [ 3021 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:50.529892 [ 3032 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:50.629090 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:50.706407 [ 3029 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:50.826830 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:51.217666 [ 3621 ] {369d5a22-169d-4e0a-9da3-e2dcfef049db} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:51.229321 [ 3621 ] {369d5a22-169d-4e0a-9da3-e2dcfef049db} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:51.247195 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (19 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:51.304079 [ 3042 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:51.532068 [ 3043 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:51.708627 [ 3055 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:51.718159 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:51.727395 [ 4294 ] {ae4523d3-8a57-4e23-ab52-143bf01d7680} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53652) (comment: 01077_mutations_index_consistency.sh) (in query: CREATE TABLE movement (`date` DateTime('Asia/Istanbul')) ENGINE = MergeTree ORDER BY toStartOfHour(date) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 27477752, compact_parts_max_granules_to_buffer = 123, compact_parts_merge_max_bytes_to_prefetch_part = 26957794, merge_max_block_size = 21352, old_parts_lifetime = 57., prefer_fetch_merged_part_size_threshold = 10508338683, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 1738966693, concurrent_part_removal_threshold = 61, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 87840, primary_key_compress_block_size = 79255), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:51.738481 [ 4294 ] {ae4523d3-8a57-4e23-ab52-143bf01d7680} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:51.967881 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:52.306697 [ 3062 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:52.357727 [ 4294 ] {2d4c0907-52ea-4d79-95b7-a7029780f339} executeQuery: Code: 60. DB::Exception: Table test_11.movement does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53672) (comment: 01077_mutations_index_consistency.sh) (in query: insert into movement select toDateTime('2020-01-22 00:00:00', 'Asia/Istanbul') + number%(23*3600) from numbers(1000000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:52.380407 [ 4294 ] {2d4c0907-52ea-4d79-95b7-a7029780f339} TCPHandler: Code: 60. DB::Exception: Table test_11.movement does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:52.534834 [ 3066 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:52.711722 [ 3071 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:52.755103 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:53.022521 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:53.071922 [ 4294 ] {f9852621-74fd-4024-afdb-988d45c9a245} executeQuery: Code: 60. DB::Exception: Table test_11.movement does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53696) (comment: 01077_mutations_index_consistency.sh) (in query: OPTIMIZE TABLE movement FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be8322 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:53.089370 [ 4294 ] {f9852621-74fd-4024-afdb-988d45c9a245} TCPHandler: Code: 60. DB::Exception: Table test_11.movement does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be8322 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:53.138423 [ 9647 ] {} ExternalDictionariesLoader: Could not update external dictionary '40f4f0d5-46fd-4e2e-8327-b350e77b0ed5', leaving the previous version, next update is scheduled at 2025-10-23 23:32:59: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:53.255109 [ 3389 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f031c251-ff48-4808-844a-5edfe9b82eeb::202510_1_64_39}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:53.309025 [ 3086 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:53.537126 [ 3096 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:53.713904 [ 3101 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:53.796162 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:53.806695 [ 4294 ] {65353c6b-7ce2-425a-98ac-1112d81966cd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'movement' in scope SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53718) (comment: 01077_mutations_index_consistency.sh) (in query: SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:53.826443 [ 4294 ] {65353c6b-7ce2-425a-98ac-1112d81966cd} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'movement' in scope SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:54.120356 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:54.262549 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:54.311643 [ 3111 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:54.539469 [ 3113 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:54.615250 [ 4294 ] {0d9f2ea7-73e5-48e3-9eb6-721a5ad50c20} executeQuery: Code: 60. DB::Exception: Table test_11.movement does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57594) (comment: 01077_mutations_index_consistency.sh) (in query: alter table movement delete where date >= toDateTime('2020-01-22T16:00:00', 'Asia/Istanbul') and date < toDateTime('2020-01-22T17:00:00', 'Asia/Istanbul') SETTINGS mutations_sync = 2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000027d92561 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000027d91dc9 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917df83 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:32:54.644340 [ 4294 ] {0d9f2ea7-73e5-48e3-9eb6-721a5ad50c20} TCPHandler: Code: 60. DB::Exception: Table test_11.movement does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const::$_0::operator()(std::shared_ptr const&) const @ 0x0000000027d92561 8. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1902: DB::DatabaseReplicated::shouldReplicateQuery(std::shared_ptr const&, std::shared_ptr const&) const @ 0x0000000027d91dc9 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917df83 10. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:32:54.716158 [ 3119 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:54.850497 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:55.166198 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:55.313890 [ 3129 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:55.340360 [ 4294 ] {3a4bceb8-91d5-484e-9946-d1366efdb7d4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'movement' in scope SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57620) (comment: 01077_mutations_index_consistency.sh) (in query: SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:55.361256 [ 4294 ] {3a4bceb8-91d5-484e-9946-d1366efdb7d4} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'movement' in scope SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:55.541580 [ 3131 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:55.718593 [ 3133 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:55.888960 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:56.061648 [ 4147 ] {5a171dc6-5a05-44a3-9f7f-a798ebf85d6e} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'movement' in scope SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57648) (comment: 01077_mutations_index_consistency.sh) (in query: SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:56.094752 [ 4147 ] {5a171dc6-5a05-44a3-9f7f-a798ebf85d6e} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'movement' in scope SELECT count(), toStartOfHour(date) AS Hour FROM movement WHERE (date >= toDateTime('2020-01-22T10:00:00', 'Asia/Istanbul')) AND (date <= toDateTime('2020-01-22T23:00:00', 'Asia/Istanbul')) GROUP BY Hour ORDER BY Hour DESC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:56.210560 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:56.316144 [ 3150 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.452618 [ 3621 ] {66e0a1b5-1105-43c4-8d6c-8035f2d805d8} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:56.456982 [ 3621 ] {66e0a1b5-1105-43c4-8d6c-8035f2d805d8} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.544101 [ 3148 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.551243 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (20 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.721092 [ 3158 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:56.767017 [ 4294 ] {668c78a0-5018-460f-b577-8f177c3ec341} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'movement' in scope SELECT count(), toStartOfHour(date) AS Hour FROM movement GROUP BY Hour ORDER BY Hour DESC. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57658) (comment: 01077_mutations_index_consistency.sh) (in query: SELECT count(), toStartOfHour(date) AS Hour FROM movement GROUP BY Hour ORDER BY Hour DESC ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:56.793112 [ 4294 ] {668c78a0-5018-460f-b577-8f177c3ec341} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'movement' in scope SELECT count(), toStartOfHour(date) AS Hour FROM movement GROUP BY Hour ORDER BY Hour DESC. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:32:56.934566 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:57.242805 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:57.318057 [ 3168 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:57.547637 [ 3177 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:57.724229 [ 3180 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:58.019322 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:58.291605 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:58.319946 [ 3188 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:58.423058 [ 4147 ] {e9d8351e-f342-45a5-a48f-ca8af26b8468} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57708) (comment: 00687_insert_into_mv.sql) (in query: CREATE TABLE test_00687 (x String) ENGINE = Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:58.427731 [ 4147 ] {e9d8351e-f342-45a5-a48f-ca8af26b8468} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:58.551428 [ 3187 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:58.726545 [ 3191 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:59.043922 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:59.213146 [ 4294 ] {3d9eeb87-6b2a-4745-8a7c-efff1f3e54b7} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57718) (comment: 00665_alter_nullable_string_to_nullable_uint8.sql) (in query: CREATE TABLE alter_00665 (`boolean_false` Nullable(String)) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 12889, min_bytes_for_wide_part = 257207481, 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 = 394795536, compact_parts_max_bytes_to_buffer = 142683483, compact_parts_max_granules_to_buffer = 240, compact_parts_merge_max_bytes_to_prefetch_part = 10886513, merge_max_block_size = 1075, old_parts_lifetime = 453., 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 = 18109762, concurrent_part_removal_threshold = 92, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 83302, primary_key_compress_block_size = 50123), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:59.236914 [ 4294 ] {3d9eeb87-6b2a-4745-8a7c-efff1f3e54b7} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:32:59.323123 [ 3202 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:59.325882 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:59.330157 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:32:59.553986 [ 3205 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:32:59.728843 [ 3214 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:00.027997 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:00.182476 [ 4294 ] {87204a36-af9d-4951-9326-1c8441da0635} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57750) (comment: 01825_new_type_json_bools.sql) (in query: CREATE TABLE t_json_bools (data JSON) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:00.188132 [ 4294 ] {87204a36-af9d-4951-9326-1c8441da0635} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:00.325290 [ 3217 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:00.446306 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:00.556304 [ 3224 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:00.731242 [ 3229 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:01.099787 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:01.327786 [ 3241 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:01.504632 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:01.558624 [ 3232 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:01.733555 [ 3244 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:01.810199 [ 3621 ] {ed71c394-ec04-4142-97c6-0005b124fd21} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:01.814748 [ 3621 ] {ed71c394-ec04-4142-97c6-0005b124fd21} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:01.829888 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (21 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:02.197705 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:02.329739 [ 3259 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:02.403246 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:02.561190 [ 3260 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:02.578601 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:02.735757 [ 3261 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:02.991830 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:03.248131 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:03.398283 [ 3277 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:03.564073 [ 3273 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:03.615943 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:03.738226 [ 3281 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.006031 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:04.297962 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:04.400446 [ 2795 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.411020 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.570045 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:04.711563 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:04.740620 [ 2787 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:05.069103 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:05.396005 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:05.402428 [ 2790 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:05.572740 [ 2805 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:05.744472 [ 2806 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:05.797297 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:06.148067 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:06.409207 [ 2817 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:06.411673 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:06.575044 [ 2816 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:06.753305 [ 2794 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:06.826999 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:07.113056 [ 3621 ] {d7efd1c8-6351-4b93-92fe-fd5588d25aa4} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:07.172149 [ 3621 ] {d7efd1c8-6351-4b93-92fe-fd5588d25aa4} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:07.189485 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:07.189664 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (22 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:07.411450 [ 2823 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:07.436224 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:07.577210 [ 2835 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:07.755271 [ 2837 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:07.886581 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:08.355353 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:08.414868 [ 2847 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.498804 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:08.579532 [ 2845 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.758512 [ 2856 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:08.898904 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:09.399032 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:09.416607 [ 2861 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:09.547452 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:09.549965 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:09.581538 [ 2859 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:09.760475 [ 2866 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:09.900885 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:10.418464 [ 2881 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:10.458461 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:10.583645 [ 2883 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:10.593867 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:10.762454 [ 2890 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:10.909714 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:11.420440 [ 2899 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:11.552761 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:11.585774 [ 2900 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:11.599613 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:11.764713 [ 2905 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:11.943014 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:12.422365 [ 2912 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:12.587901 [ 2915 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:12.604509 [ 3621 ] {2c32c088-b1b1-4171-8c19-fc8ac537ea5f} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:12.617523 [ 3621 ] {2c32c088-b1b1-4171-8c19-fc8ac537ea5f} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:12.630347 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:12.635453 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (23 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:12.694700 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:12.766946 [ 2920 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:13.004671 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:13.424494 [ 2931 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:13.590043 [ 2934 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:13.683963 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:13.711220 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:13.769450 [ 2936 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:14.077054 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:14.427427 [ 2949 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:14.592022 [ 2945 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:14.649199 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:14.719648 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:14.751189 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:14.771805 [ 2946 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:15.102763 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:15.429437 [ 2963 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:15.594072 [ 2962 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:15.774022 [ 2966 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:15.786689 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:15.787242 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:16.125091 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:16.178761 [ 3380 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f031c251-ff48-4808-844a-5edfe9b82eeb::202510_1_67_42}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:16.431752 [ 2975 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:16.596400 [ 2979 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:16.776004 [ 2983 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:16.843012 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:16.875997 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:17.159701 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:17.433830 [ 2991 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:17.599879 [ 2996 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:17.779037 [ 2999 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:17.895009 [ 3621 ] {f9023821-bc7b-4ae1-8c44-b515133b7782} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:17.899536 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:17.899981 [ 3621 ] {f9023821-bc7b-4ae1-8c44-b515133b7782} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:17.921266 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:17.926818 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (24 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:18.220241 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:18.436289 [ 3013 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:18.601980 [ 3011 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:18.781288 [ 2998 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:18.915282 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:18.976082 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:19.258143 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:19.438981 [ 3024 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:19.604194 [ 3034 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:19.783463 [ 3032 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:19.852484 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:19.971903 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:20.037978 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:20.258495 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:20.444465 [ 3038 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:20.606622 [ 3040 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:20.785710 [ 3045 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:21.045241 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:21.073190 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:21.276555 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:21.446860 [ 3056 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:21.608979 [ 3059 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:21.787921 [ 3052 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:22.098231 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:22.162490 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:22.288928 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:22.449279 [ 3072 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:22.611641 [ 3073 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:22.790003 [ 3079 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:23.158296 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:23.177193 [ 3621 ] {05eeaaa8-e4ba-4b17-8ee5-aeb0a9c170b7} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:23.189117 [ 3621 ] {05eeaaa8-e4ba-4b17-8ee5-aeb0a9c170b7} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:23.203025 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:23.207331 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (25 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:23.362911 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:23.451383 [ 3084 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:23.614631 [ 3088 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:23.792977 [ 3095 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:24.194168 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:24.245105 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:24.379320 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:24.453334 [ 3100 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:24.617603 [ 3107 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:24.796308 [ 3112 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:24.973726 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:25.267744 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:25.319315 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:25.414756 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:25.464282 [ 3121 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:25.619586 [ 3130 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:25.798576 [ 3131 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:26.320170 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:26.393092 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:26.466227 [ 3143 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:26.514560 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:26.621899 [ 3149 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:26.801052 [ 3154 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:27.382229 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:27.469009 [ 3159 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:27.470173 [ 4294 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:27.527463 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:27.624404 [ 3162 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:27.806868 [ 3170 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:28.471144 [ 3178 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:28.474813 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:28.498247 [ 3621 ] {31e5c757-1fa5-4a37-8786-082917354321} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:28.500452 [ 3621 ] {31e5c757-1fa5-4a37-8786-082917354321} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:28.525767 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (26 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:28.578472 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:28.586854 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:28.626483 [ 3182 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:28.809522 [ 3181 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:29.473211 [ 3201 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:29.538614 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:29.630429 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:29.630709 [ 3196 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:29.667299 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:29.811886 [ 3204 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:30.062924 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:30.545263 [ 3211 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:30.628606 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:30.632854 [ 3213 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:30.670739 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:30.726159 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:30.814050 [ 3217 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:31.547803 [ 3236 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:31.634842 [ 3237 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:31.698695 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:31.744918 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:31.816215 [ 3238 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:31.842409 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:32.549999 [ 3250 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:32.636979 [ 3242 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:32.720346 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:32.819114 [ 3255 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:32.824483 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:32.891900 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:33.552280 [ 3264 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:33.639334 [ 3267 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:33.818184 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:33.825633 [ 3271 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:33.858716 [ 3621 ] {59ff4c08-7806-4587-9a90-aa7aaf06212f} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:33.876449 [ 3621 ] {59ff4c08-7806-4587-9a90-aa7aaf06212f} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:33.912494 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (27 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:33.941407 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:33.973923 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:34.554574 [ 3279 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:34.641579 [ 3276 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:34.831191 [ 2791 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:34.859263 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:34.940620 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:35.056827 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:35.123472 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:35.557304 [ 2786 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:35.643864 [ 2787 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:35.833764 [ 2799 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:35.977043 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:35.992996 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:36.126733 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:36.559720 [ 2810 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:36.645921 [ 2776 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:36.836068 [ 2797 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:36.988333 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:36.992703 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:37.182603 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:37.561826 [ 2818 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:37.647923 [ 2820 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:37.838151 [ 2827 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:38.042417 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:38.049007 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:38.246285 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:38.564120 [ 2832 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:38.650361 [ 2838 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:38.840298 [ 2840 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:39.070071 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:39.102953 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:39.244498 [ 3621 ] {312d6017-970c-45fb-9e31-bfdbf521af79} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:39.247991 [ 3621 ] {312d6017-970c-45fb-9e31-bfdbf521af79} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:39.258489 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (28 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:39.267490 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:39.566716 [ 2857 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:39.652318 [ 2860 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:39.842826 [ 2859 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:40.074815 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:40.143271 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:40.201238 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:40.321595 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:40.569330 [ 2873 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:40.655538 [ 2875 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:40.845441 [ 2878 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:41.114409 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:41.249022 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:41.414282 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:41.571983 [ 2894 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:41.665152 [ 2892 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:41.848346 [ 2899 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:42.137531 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:42.378591 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:42.503501 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:42.576181 [ 2906 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:42.667597 [ 2909 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:42.851315 [ 2910 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:43.201983 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:43.454495 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:43.578361 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:43.581228 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:43.670476 [ 2923 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:43.854236 [ 2927 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:44.191485 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:44.482823 [ 3621 ] {ac7f45db-7cfa-48d0-af4b-5b49098a5c8d} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:44.486837 [ 3621 ] {ac7f45db-7cfa-48d0-af4b-5b49098a5c8d} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:44.502211 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (29 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:44.526886 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:44.580963 [ 2936 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:44.674840 [ 2937 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:44.701977 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:44.856930 [ 2942 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:45.220581 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:45.290339 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:45.575858 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:45.583694 [ 2952 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:45.676864 [ 2953 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:45.742572 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:45.859171 [ 2958 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:46.276443 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:46.585796 [ 2969 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:46.620666 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:46.680248 [ 2974 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:46.774033 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:46.863044 [ 2972 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.329725 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:47.588153 [ 2985 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.683533 [ 2987 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:47.729511 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:47.861906 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:47.865091 [ 2991 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:48.402096 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:48.590165 [ 3006 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:48.685602 [ 3007 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:48.783174 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:48.904673 [ 3011 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:48.916805 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:49.507847 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:49.592673 [ 3027 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:49.687452 [ 3024 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:49.835309 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:49.835943 [ 3621 ] {f70a0a0a-c241-4658-909e-e4bcdcb4c464} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:49.844616 [ 3621 ] {f70a0a0a-c241-4658-909e-e4bcdcb4c464} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:49.873426 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (30 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:49.906713 [ 3033 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:49.949621 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:50.365247 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:50.537935 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:50.595208 [ 3038 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:50.689621 [ 3039 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:50.916732 [ 3042 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:50.923820 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:51.033736 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:51.566253 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:51.597589 [ 3053 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:51.691772 [ 3054 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:51.914649 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:51.919303 [ 3059 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:52.063224 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:52.598042 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:52.599847 [ 3070 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:52.693748 [ 3071 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:52.923417 [ 3076 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:52.978835 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:53.095174 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:53.602060 [ 3078 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:53.617274 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:53.696000 [ 3085 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:53.925723 [ 3090 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:54.012001 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:54.132223 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:54.603969 [ 3102 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:54.694405 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:54.701057 [ 3104 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:54.927759 [ 3105 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:55.022322 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:55.182776 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:55.196207 [ 3621 ] {09913c8d-e7d2-4bf7-aedd-e28f50ccc4b8} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:33:55.199266 [ 3621 ] {09913c8d-e7d2-4bf7-aedd-e28f50ccc4b8} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:55.210720 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (31 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:55.445253 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:55.606020 [ 3117 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:55.703314 [ 3120 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:55.752430 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:55.930010 [ 3126 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:56.035703 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:56.207969 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:56.608091 [ 3134 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:56.705641 [ 3139 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:56.802972 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:56.935643 [ 3141 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:57.037579 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:57.217122 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:57.610627 [ 3154 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:57.708147 [ 3152 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:57.843733 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:57.937922 [ 3158 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:58.103463 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:58.257959 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:58.613341 [ 3171 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:58.710842 [ 3176 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:58.886731 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:58.940869 [ 3174 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:59.185474 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:59.310187 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:59.615524 [ 3187 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:59.713283 [ 3190 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:33:59.895943 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:33:59.943555 [ 3166 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:00.213267 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:00.357648 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:00.402443 [ 3621 ] {ec4a6e15-03f7-4309-b510-005f6e145807} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:00.405858 [ 3621 ] {ec4a6e15-03f7-4309-b510-005f6e145807} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:00.421555 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (32 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:00.603487 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:00.617986 [ 3198 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:00.715636 [ 3202 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:00.915611 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:00.945659 [ 3205 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:01.294204 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:01.416742 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:01.620198 [ 3218 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:01.718428 [ 3221 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:01.947975 [ 3223 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:01.973842 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:02.358998 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:02.494174 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:02.622810 [ 3235 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:02.720758 [ 3237 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:02.950612 [ 3249 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:03.028740 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:03.416624 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:03.564349 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:03.625057 [ 3254 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:03.723011 [ 3256 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:03.952916 [ 3263 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:04.023220 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:04.529523 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:04.627146 [ 3274 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:04.643601 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:04.724860 [ 3273 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:04.954969 [ 3282 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:05.032378 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:05.589183 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:05.616239 [ 3621 ] {ddb35e38-c2ed-4d05-a7bc-9151e23448f5} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:05.624677 [ 3621 ] {ddb35e38-c2ed-4d05-a7bc-9151e23448f5} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:05.629862 [ 3280 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:05.640861 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (33 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:05.692201 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:05.709003 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:05.726934 [ 2772 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:05.956967 [ 2800 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:06.058785 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:06.633004 [ 2805 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:06.680886 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:06.729254 [ 2784 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:06.775443 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:06.959848 [ 2782 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:07.072562 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:07.642337 [ 2797 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:07.703311 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:07.731496 [ 2815 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:07.856271 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:07.963775 [ 2819 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.049805 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:08.644607 [ 2833 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.733764 [ 2829 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:08.736836 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:08.914520 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:08.965881 [ 2838 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.109122 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:09.647232 [ 2843 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.735995 [ 2845 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.821076 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:09.968384 [ 2852 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:09.987060 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:10.211702 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:10.649533 [ 2862 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.737997 [ 2870 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.761874 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.864578 [ 3621 ] {b064ef2d-d679-4a9b-be6e-c50f8e417868} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:10.864929 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:10.870474 [ 3621 ] {b064ef2d-d679-4a9b-be6e-c50f8e417868} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.885216 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (34 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:10.970606 [ 2874 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.050684 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:11.261113 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:11.651973 [ 2885 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.740129 [ 2888 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.975272 [ 2890 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:11.995165 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:12.126234 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:12.291112 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:12.654878 [ 2899 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.752436 [ 2901 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:12.977523 [ 2905 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.073321 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:13.218888 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:13.286448 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:13.657409 [ 2914 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.754617 [ 2912 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:13.979701 [ 2919 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:14.092493 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:14.267354 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:14.326766 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:14.757171 [ 2934 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:14.836083 [ 2932 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:14.987152 [ 2939 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.128231 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:15.426365 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:15.447258 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:15.759441 [ 2946 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.838313 [ 2954 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.904897 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:15.989359 [ 2958 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.100958 [ 3621 ] {f51c5d24-5cc9-4d39-ae47-db01438a91d3} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:16.106936 [ 3621 ] {f51c5d24-5cc9-4d39-ae47-db01438a91d3} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.122782 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (35 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.296520 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:16.455697 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:16.547237 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:16.761389 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.840313 [ 2972 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:16.991704 [ 2976 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.381544 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:17.545599 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:17.632318 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:17.763824 [ 2990 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.846755 [ 2995 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:17.994043 [ 2986 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.457634 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:18.598014 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:18.769799 [ 3006 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.790057 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:18.848788 [ 3005 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:18.996180 [ 3009 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.512857 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:19.723287 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:19.771878 [ 3025 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.847155 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:19.851682 [ 3021 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:19.998473 [ 3034 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:20.608782 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:20.718168 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:20.774329 [ 3037 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:20.853905 [ 3038 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:20.886992 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:21.000491 [ 3042 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.031796 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.376317 [ 3621 ] {18cbbc8d-4979-42a2-9d39-cd2525dc062d} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:21.385916 [ 3621 ] {18cbbc8d-4979-42a2-9d39-cd2525dc062d} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.400973 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (36 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.689380 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:21.763058 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:21.776494 [ 3058 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:21.856759 [ 3057 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.003853 [ 3052 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.007855 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:22.781631 [ 3066 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:22.782916 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:22.842338 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:22.858800 [ 3071 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.005743 [ 3077 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.108484 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:23.783716 [ 3085 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.849355 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:23.860719 [ 3090 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:23.985406 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:24.008164 [ 3089 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.258109 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:24.793268 [ 3103 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.862972 [ 3102 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:24.902749 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:25.010348 [ 3104 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.066357 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:25.343206 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:25.795756 [ 3119 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.866692 [ 3120 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:25.996752 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:26.012262 [ 3122 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.057426 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:26.118924 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.412062 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:26.767973 [ 3621 ] {416a428c-f9f0-49ed-8af2-a4974899c532} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:26.796996 [ 3621 ] {416a428c-f9f0-49ed-8af2-a4974899c532} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.798236 [ 3139 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.818359 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (37 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:26.868943 [ 3136 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.014076 [ 3142 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.040119 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:27.054108 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:27.657283 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:27.800539 [ 3153 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:27.871281 [ 3156 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.016214 [ 3151 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.029656 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:28.055898 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:28.776996 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:28.802513 [ 3160 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:28.879840 [ 3168 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.018284 [ 3176 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.111764 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:29.120813 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:29.804530 [ 3185 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.882082 [ 3183 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:29.934325 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:30.020253 [ 3181 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.122428 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:30.128710 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:30.807130 [ 3197 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:30.884362 [ 3201 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.003470 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:31.078410 [ 3196 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.157599 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:31.175693 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:31.263749 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.809219 [ 3212 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:31.894676 [ 3216 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.059176 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:32.075645 [ 3621 ] {c71f1226-6af2-45b1-8d11-4ed1cefa2a10} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:32.089950 [ 3213 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.090764 [ 3621 ] {c71f1226-6af2-45b1-8d11-4ed1cefa2a10} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.157430 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (38 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.230579 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:32.299745 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:32.811570 [ 3231 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:32.896455 [ 3230 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.092145 [ 3155 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.135718 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:33.294146 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:33.332101 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:33.813846 [ 3232 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:33.898636 [ 3244 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:34.093965 [ 3243 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:34.194022 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:34.342995 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:34.412971 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:34.816168 [ 3262 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:34.900950 [ 3261 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:35.104696 [ 3265 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:35.253628 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:35.436129 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:35.473422 [ 6609 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:35.819505 [ 3283 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:35.903822 [ 2773 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:36.107053 [ 3270 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:36.304701 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:36.387343 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:36.455644 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:36.595244 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:36.821715 [ 2786 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:36.946617 [ 2803 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:37.109550 [ 2792 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:37.410586 [ 3621 ] {2244c5f2-5b18-4847-8c8d-fd880dcfb0e5} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:37.418702 [ 3621 ] {2244c5f2-5b18-4847-8c8d-fd880dcfb0e5} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:37.420400 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:37.444437 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (39 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:37.520769 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:37.647300 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:37.824264 [ 2812 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:37.948933 [ 2793 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.111820 [ 2797 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.566911 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:38.630086 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:38.737060 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:38.826684 [ 2821 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:38.951316 [ 2827 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:39.113970 [ 2830 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:39.626214 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:39.677339 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:39.825344 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:39.828985 [ 2840 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:39.955103 [ 2841 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:40.116143 [ 2839 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:40.711480 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:40.749896 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:40.834328 [ 2850 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:40.884330 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:40.961050 [ 2848 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:41.119271 [ 2853 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:41.487899 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:41.724867 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:41.836564 [ 2868 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:41.845442 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:41.943403 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:41.965821 [ 2867 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:42.121406 [ 2876 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:42.781469 [ 3621 ] {94a642b8-5453-4958-914b-2a43627c668f} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:42.784034 [ 3621 ] {94a642b8-5453-4958-914b-2a43627c668f} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:42.785968 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:42.792665 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (40 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:42.838433 [ 2888 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:42.963412 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:42.967946 [ 2891 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:43.038244 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:43.123657 [ 2896 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:43.812574 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:43.841438 [ 2905 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:43.998069 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:44.034674 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:44.040528 [ 2902 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:44.125656 [ 2907 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:44.844478 [ 2920 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:44.869181 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:45.042600 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:45.106740 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:45.116067 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:45.127647 [ 2924 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:45.846740 [ 2932 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:45.900455 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:46.044857 [ 2938 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:46.129649 [ 2939 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:46.144150 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:46.182422 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:46.594483 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:46.848888 [ 2949 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:46.943583 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:47.047054 [ 2950 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:47.132002 [ 2952 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:47.228984 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:47.257763 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:47.851145 [ 2957 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:47.968563 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:48.051922 [ 2962 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:48.065179 [ 3621 ] {5a0468e7-f101-40c5-8b70-695222d72398} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:48.074946 [ 3621 ] {5a0468e7-f101-40c5-8b70-695222d72398} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:48.106724 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (41 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:48.171702 [ 2966 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:48.282685 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:48.305688 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:48.853196 [ 2974 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:49.011728 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:49.053929 [ 2976 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:49.173850 [ 2975 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:49.328676 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:49.349090 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:49.855406 [ 2990 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:50.055974 [ 2989 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:50.083223 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:50.177354 [ 2993 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:50.474133 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:50.475617 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:50.857610 [ 3003 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:51.058412 [ 3006 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:51.160137 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:51.180092 [ 3007 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:51.510392 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:51.528029 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:51.679629 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:51.859857 [ 3016 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:52.060514 [ 3025 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:52.173865 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:52.182325 [ 3021 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:52.548569 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:52.711657 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:52.865444 [ 3023 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:53.062904 [ 3028 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:53.184241 [ 3041 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:53.194855 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:53.510814 [ 3621 ] {144d6205-d9a2-4fae-81f9-569c2b87503d} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:53.527093 [ 3621 ] {144d6205-d9a2-4fae-81f9-569c2b87503d} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:53.541623 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (42 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:53.611886 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:53.774293 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:53.869462 [ 3049 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:54.064915 [ 3046 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:54.186383 [ 3048 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:54.197591 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:54.686701 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:54.852187 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:54.871786 [ 3052 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:55.066810 [ 3063 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:55.189560 [ 3065 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:55.217398 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:55.754921 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:55.873930 [ 3076 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:55.903316 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:56.069238 [ 3075 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:56.192624 [ 3083 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:56.271517 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:56.766061 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:56.841697 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:56.876134 [ 3086 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:56.992147 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:57.071371 [ 3089 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:57.194975 [ 3095 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:57.324693 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:57.872786 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:57.878001 [ 3102 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:58.061488 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:58.074493 [ 3105 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:58.197106 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:58.349567 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:58.857707 [ 3621 ] {f0551480-5a71-4a8e-945e-c985929c4d24} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:34:58.861363 [ 3621 ] {f0551480-5a71-4a8e-945e-c985929c4d24} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:58.875874 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (43 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:58.883650 [ 3113 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:58.899020 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:59.076476 [ 3119 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:59.181516 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:59.202880 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:59.395868 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:34:59.885680 [ 3128 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:34:59.961859 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:00.078642 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:00.209241 [ 3135 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:00.227785 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:00.506624 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:00.888044 [ 3145 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:01.010234 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:01.080702 [ 3149 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:01.211781 [ 3152 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:01.320298 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:01.524960 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:01.890524 [ 3159 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:01.943881 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:02.031588 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:02.087896 [ 3164 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:02.214006 [ 3170 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:02.376553 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:02.591777 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:02.899711 [ 3179 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:03.051121 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:03.090020 [ 3182 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:03.215873 [ 3185 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:03.434355 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:03.617153 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:03.902113 [ 3166 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:04.092556 [ 3193 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:04.173748 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:04.179003 [ 3621 ] {9bdc671b-6180-49de-9cb8-82ef89b2e86e} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:04.181514 [ 3621 ] {9bdc671b-6180-49de-9cb8-82ef89b2e86e} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:04.191502 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (44 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:04.217880 [ 3194 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:04.515882 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:04.757665 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:04.904524 [ 3196 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:05.094757 [ 3209 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:05.199334 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:05.246720 [ 3215 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:05.548114 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:05.784184 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:05.908603 [ 3223 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:06.097050 [ 3225 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:06.217376 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:06.249012 [ 3233 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:06.604464 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:06.814462 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:06.910757 [ 3235 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:07.036927 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:07.100442 [ 3248 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:07.248737 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:07.251152 [ 3246 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:07.690676 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:07.852118 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:07.913186 [ 3254 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:08.102560 [ 3257 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:08.253571 [ 3260 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:08.347485 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:08.768739 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:08.915713 [ 3268 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:08.939274 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:09.105610 [ 3271 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:09.262662 [ 3272 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:09.373325 [ 3621 ] {7e4da0b4-256a-4614-b610-33e3731bcd1a} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:09.402946 [ 3621 ] {7e4da0b4-256a-4614-b610-33e3731bcd1a} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:09.414133 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:09.421977 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (45 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:09.854183 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:09.918788 [ 3281 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:09.982601 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:10.108545 [ 2775 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:10.265084 [ 3276 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:10.579315 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:10.910489 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:10.920923 [ 2796 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:10.971552 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:11.110818 [ 2787 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:11.274948 [ 2792 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:11.705003 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:11.923521 [ 2804 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:11.958575 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:12.059890 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:12.113075 [ 2780 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:12.199411 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:12.276923 [ 2808 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:12.717492 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:12.925722 [ 2813 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:12.993434 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:13.115517 [ 2815 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:13.125956 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:13.279385 [ 2807 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:13.793500 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:13.927786 [ 2827 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:14.051976 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:14.117888 [ 2830 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:14.190838 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:14.282396 [ 2829 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:14.798927 [ 3621 ] {80826bb5-d227-4a45-a947-3fdba9b86c56} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:14.809537 [ 3621 ] {80826bb5-d227-4a45-a947-3fdba9b86c56} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:14.823890 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:14.826806 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (46 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:14.929886 [ 2828 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:15.116370 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:15.123409 [ 2832 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:15.226552 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:15.285598 [ 2840 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:15.914650 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:15.932258 [ 2851 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:16.125940 [ 2856 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:16.175553 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:16.257301 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:16.288117 [ 2855 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:16.980679 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:16.934238 [ 2860 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:17.127908 [ 2861 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:17.202762 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:17.291046 [ 2859 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:17.307985 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:17.504783 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:18.017285 [ 2872 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:18.014246 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:18.130284 [ 2875 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:18.238355 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:18.293163 [ 2876 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:18.377924 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:19.019980 [ 2894 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:19.049051 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:19.132398 [ 2889 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:19.295820 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:19.296995 [ 2896 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:19.514507 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:20.021893 [ 2904 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:20.041326 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:20.136137 [ 2908 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:20.251351 [ 3621 ] {cd3c6420-882b-4e00-988e-4460bd282552} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:20.255666 [ 3621 ] {cd3c6420-882b-4e00-988e-4460bd282552} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:20.279075 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (47 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:20.299147 [ 2902 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:20.400881 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:20.534233 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:21.024136 [ 2919 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:21.046817 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:21.139722 [ 2918 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:21.301248 [ 2920 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:21.478550 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:21.593526 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:22.026841 [ 2938 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:22.117615 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:22.142139 [ 2939 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:22.303340 [ 2943 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:22.547169 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:22.616940 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:22.684387 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:23.029547 [ 2946 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:23.128005 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:23.168363 [ 2953 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:23.305648 [ 2954 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:23.614865 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:23.663225 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:24.032077 [ 2968 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:24.128990 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:24.170990 [ 2971 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:24.308242 [ 2970 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:24.672044 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:24.797435 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:25.034620 [ 2982 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:25.173715 [ 2988 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:25.276879 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:25.310157 [ 2987 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:25.664263 [ 3621 ] {30b59cca-60ee-4864-971d-1400436ffd3f} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:25.669484 [ 3621 ] {30b59cca-60ee-4864-971d-1400436ffd3f} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:25.681910 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (48 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:25.712546 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:25.832166 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:26.037258 [ 2997 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:26.176015 [ 3000 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:26.312494 [ 3003 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:26.398548 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:26.820669 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:26.888017 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:27.039827 [ 3015 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:27.178569 [ 3016 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:27.314625 [ 3019 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:27.410146 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:27.786112 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:27.864812 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:27.953501 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:28.043942 [ 3033 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:28.180584 [ 3035 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:28.316783 [ 3031 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:28.437878 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:28.953500 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:28.970658 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:29.049147 [ 3044 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:29.182631 [ 3043 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:29.319098 [ 3056 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:29.519788 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:29.990406 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:30.008908 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:30.058122 [ 3059 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:30.184706 [ 3055 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:30.321402 [ 3061 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:30.650345 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:31.001664 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:31.041234 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:31.060210 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:31.146845 [ 3621 ] {164d0a5c-41c4-49c0-96a6-84dbe7891674} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:31.152523 [ 3621 ] {164d0a5c-41c4-49c0-96a6-84dbe7891674} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:31.163455 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (49 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:31.186981 [ 3071 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:31.323846 [ 3073 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:31.698653 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:32.064571 [ 3078 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:32.067289 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:32.132241 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:32.190088 [ 3087 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:32.326057 [ 3088 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:32.763005 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:32.907022 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:33.075183 [ 3103 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:33.113667 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:33.194212 [ 3100 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:33.227476 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:33.328381 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:33.785382 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:34.078670 [ 3116 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:34.113623 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:34.196187 [ 3118 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:34.263500 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:34.330738 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:34.615783 [ 3378 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f031c251-ff48-4808-844a-5edfe9b82eeb::202510_1_85_60}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:34.832304 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:35.081006 [ 3132 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:35.171638 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:35.200905 [ 3135 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:35.309605 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:35.332835 [ 3137 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:35.927706 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:36.083503 [ 3154 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:36.191643 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:36.203193 [ 3153 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:36.335272 [ 3158 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:36.351831 [ 3621 ] {63f92117-a7d9-494c-886b-e6cb76239c63} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:36.355897 [ 3621 ] {63f92117-a7d9-494c-886b-e6cb76239c63} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:36.369547 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (50 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:36.380025 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:36.976073 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:37.085603 [ 3171 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:37.211307 [ 3169 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:37.287922 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:37.337783 [ 3176 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:37.512438 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:38.060626 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:38.087817 [ 3184 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:38.091458 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:38.213259 [ 3183 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:38.340198 [ 3186 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:38.355215 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:38.650711 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:39.054925 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:39.090223 [ 3193 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:39.215693 [ 3197 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:39.342511 [ 3200 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:39.389851 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:39.692666 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:40.052765 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:40.092507 [ 3212 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:40.217981 [ 3215 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:40.344778 [ 3214 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:40.422000 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:40.770494 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:41.073511 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:41.095032 [ 3228 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:41.220643 [ 3231 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:41.347050 [ 3229 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:41.473967 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:41.672867 [ 3621 ] {4039934a-c115-46ff-af59-af22f5888ddb} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:41.678170 [ 3621 ] {4039934a-c115-46ff-af59-af22f5888ddb} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:41.697683 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (51 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:41.830489 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:42.097204 [ 3238 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:42.131725 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:42.227107 [ 3249 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:42.349587 [ 3244 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:42.561743 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:42.920788 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:43.099355 [ 3253 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:43.137894 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:43.160831 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:43.230321 [ 3256 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:43.351828 [ 3262 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:43.697386 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:44.008102 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:44.101814 [ 3272 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:44.152824 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:44.235798 [ 3277 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:44.354291 [ 3275 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:44.775611 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:45.105097 [ 3280 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:45.108359 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:45.161297 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:45.187987 [ 3388 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7375513c-4863-4bde-85c7-c66f94b39dbd::202510_1_81_16}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:45.322083 [ 2795 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:45.356370 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:46.023517 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:46.107761 [ 2780 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:46.175694 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:46.216252 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:46.340363 [ 2777 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:46.358333 [ 2808 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:46.994272 [ 3621 ] {f0e7e83c-9716-4313-aae3-1533c052d03d} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:47.001998 [ 3621 ] {f0e7e83c-9716-4313-aae3-1533c052d03d} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:47.017880 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (52 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:47.024027 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:47.109732 [ 2818 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:47.196048 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:47.279347 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:47.342553 [ 2794 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:47.360336 [ 2821 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:48.111951 [ 2833 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:48.150121 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:48.222421 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:48.256407 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:48.344870 [ 2837 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:48.362684 [ 2828 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:48.413769 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:49.114185 [ 2846 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:49.184045 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:49.286759 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:49.355882 [ 2850 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:49.364913 [ 2852 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:49.439966 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:50.116378 [ 2859 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:50.221784 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:50.357945 [ 2870 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:50.367218 [ 2868 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:50.374535 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:50.577622 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:51.118328 [ 2883 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:51.253699 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:51.360253 [ 2882 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:51.369603 [ 2886 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:51.422839 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:51.628122 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:52.120682 [ 2897 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:52.267200 [ 3621 ] {74634587-f2b6-446b-a29c-3bf92cd05c53} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:52.283039 [ 3621 ] {74634587-f2b6-446b-a29c-3bf92cd05c53} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:52.287888 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:52.307942 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (53 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:52.362378 [ 2903 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:52.371474 [ 2904 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:52.476854 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:52.636181 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:53.122633 [ 2912 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:53.336577 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:53.364348 [ 2918 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:53.373681 [ 2925 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:53.446179 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:53.532667 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:53.681718 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:54.124978 [ 2927 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:54.366367 [ 2934 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:54.375757 [ 2933 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:54.387868 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:54.560171 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:54.716063 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:55.127296 [ 2943 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:55.368600 [ 2947 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:55.378064 [ 2951 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:55.418401 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:55.619566 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:55.786326 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:56.129886 [ 2961 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:56.371026 [ 2967 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:56.382117 [ 2962 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:56.530679 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:56.749638 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:56.931100 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:57.131938 [ 2976 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:57.373432 [ 2983 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:57.384170 [ 2984 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:57.548219 [ 3621 ] {1d2a616c-ebb0-43f2-b93a-6fe3665e4608} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:35:57.552186 [ 3621 ] {1d2a616c-ebb0-43f2-b93a-6fe3665e4608} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:57.640350 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:57.670719 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (54 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:57.830610 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:57.953950 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:58.134009 [ 2999 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:58.376055 [ 2997 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:58.386763 [ 2994 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:58.666163 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:58.786785 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:58.909951 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:59.002925 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:59.136035 [ 3008 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:59.378465 [ 3020 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:59.389301 [ 3016 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:35:59.830631 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:35:59.947046 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:00.071849 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:00.138194 [ 3034 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:00.380953 [ 3035 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:00.391691 [ 3029 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:00.989320 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:01.060781 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:01.140466 [ 3042 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:01.179073 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:01.383250 [ 3047 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:01.393754 [ 3046 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:02.017851 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:02.110129 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:02.143058 [ 3055 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:02.279090 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:02.385632 [ 3060 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:02.396278 [ 3062 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:02.973829 [ 3621 ] {0db7fff3-ffc6-4b6b-90c4-8255194c4d1a} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:02.981199 [ 3621 ] {0db7fff3-ffc6-4b6b-90c4-8255194c4d1a} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:02.995587 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (55 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:03.057667 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:03.145058 [ 3071 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:03.224318 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:03.354574 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:03.388303 [ 3073 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:03.398405 [ 3080 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:03.752102 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:04.147419 [ 3090 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:04.159718 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:04.299448 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:04.390781 [ 3091 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:04.400517 [ 3094 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:04.539334 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:05.149986 [ 3102 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:05.262226 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:05.393310 [ 3107 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:05.402521 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:05.441041 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:05.579814 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:06.152405 [ 3120 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:06.331764 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:06.395426 [ 3124 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:06.404458 [ 3122 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:06.575873 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:06.653874 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:07.155240 [ 3129 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:07.397616 [ 3134 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:07.410354 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:07.478584 [ 3133 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:07.606535 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:07.729412 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:08.158739 [ 3146 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:08.362506 [ 3621 ] {4c0ee4b7-593c-4da1-a0d1-b1926818fd12} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:08.369707 [ 3621 ] {4c0ee4b7-593c-4da1-a0d1-b1926818fd12} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:08.398359 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (56 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:08.399655 [ 3154 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:08.462504 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:08.480999 [ 3147 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:08.679168 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:08.792421 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:08.891362 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:09.161176 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:09.401580 [ 3162 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:09.483382 [ 3163 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:09.485478 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:09.743730 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:09.857807 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:10.163585 [ 3172 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:10.403703 [ 3178 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:10.485457 [ 3173 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:10.628826 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:10.759841 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:10.941147 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:11.165899 [ 3187 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:11.405863 [ 3190 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:11.487632 [ 3191 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:11.781957 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:11.804328 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:11.971462 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:12.171355 [ 3198 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:12.408728 [ 3208 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:12.489628 [ 3209 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:12.855124 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:12.898587 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:13.032831 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:13.173439 [ 3218 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:13.411070 [ 3226 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:13.491751 [ 3227 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:13.766647 [ 3621 ] {9215ee40-e80e-490c-8909-fc1158870ae7} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:13.795982 [ 3621 ] {9215ee40-e80e-490c-8909-fc1158870ae7} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:13.818430 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (57 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:13.876474 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:13.957790 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:14.020114 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:14.056583 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:14.175520 [ 3233 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:14.413547 [ 3240 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:14.575243 [ 3238 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:14.927235 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:14.990437 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:15.083759 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:15.177434 [ 3250 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:15.416112 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:15.577195 [ 3256 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:15.985537 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:16.018102 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:16.168273 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:16.179557 [ 3268 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:16.516207 [ 3271 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:16.579429 [ 3277 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:17.038370 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:17.063166 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:17.182063 [ 2773 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:17.185901 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:17.518214 [ 3270 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:17.581592 [ 3280 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:18.067283 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:18.091701 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:18.184492 [ 2800 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:18.232851 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:18.520647 [ 2785 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:18.584053 [ 2806 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:19.079158 [ 3621 ] {9bad4f42-f1cc-477e-a2f7-3e820f6c2c64} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:19.081790 [ 3621 ] {9bad4f42-f1cc-477e-a2f7-3e820f6c2c64} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:19.098328 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (58 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:19.100885 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:19.107105 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:19.145506 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:19.202015 [ 2782 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:19.271998 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:19.522855 [ 2797 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:19.585858 [ 2817 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:20.162124 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:20.189610 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:20.215200 [ 2794 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:20.344294 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:20.525144 [ 2826 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:20.587886 [ 2824 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:21.152019 [ 4049 ] {56a39a6a-1a31-4be0-a70f-a15d5b5cc8ed} executeQuery: Code: 341. DB::Exception: Timeout: Cannot enqueue query on this replica, most likely because replica is busy with previous queue entries. (UNFINISHED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46218) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1_repl_01111_14.rmt_9617_8466_156 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:322: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db61a8 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:21.163686 [ 4049 ] {56a39a6a-1a31-4be0-a70f-a15d5b5cc8ed} TCPHandler: Code: 341. DB::Exception: Timeout: Cannot enqueue query on this replica, most likely because replica is busy with previous queue entries. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:322: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db61a8 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:21.217120 [ 2828 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:21.217610 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:21.278378 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:21.413465 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:21.527241 [ 2842 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:21.590193 [ 2849 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:22.219071 [ 2852 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:22.250621 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:22.336490 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:22.488458 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:22.529283 [ 2853 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:22.592525 [ 2863 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:23.221151 [ 2875 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:23.282558 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:23.426285 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:23.536125 [ 2878 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:23.544474 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:23.595241 [ 2880 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:24.198682 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:24.223213 [ 2888 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:24.285076 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:24.445128 [ 3621 ] {5908f71f-7a13-455f-8176-d8a43857ae6e} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:24.448282 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:24.455810 [ 3621 ] {5908f71f-7a13-455f-8176-d8a43857ae6e} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:24.476979 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (59 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:24.568484 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:24.597561 [ 2897 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:24.628577 [ 2898 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:25.225223 [ 2905 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:25.303547 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:25.441728 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:25.599812 [ 2914 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:25.631015 [ 2912 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:25.634436 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:26.227707 [ 2924 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:26.351075 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:26.502666 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:26.603961 [ 2930 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:26.647158 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:26.670782 [ 2931 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:27.230131 [ 2938 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:27.348857 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:27.527468 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:27.608604 [ 2944 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:27.675707 [ 2949 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:27.722339 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:28.232503 [ 2955 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:28.438378 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:28.636428 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:28.678031 [ 2967 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:28.695509 [ 2963 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:28.866014 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:29.235784 [ 2970 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:29.337329 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:29.528421 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:29.680536 [ 2980 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:29.697714 [ 2979 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:29.718366 [ 3621 ] {e32334f8-c54c-4ec8-ad5d-021663c2d53e} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:29.730608 [ 3621 ] {e32334f8-c54c-4ec8-ad5d-021663c2d53e} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:29.753941 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:29.760991 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (60 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:29.886429 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:30.237889 [ 2993 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:30.567668 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:30.683377 [ 2997 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:30.699745 [ 2994 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:30.843729 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:30.955480 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:31.240267 [ 3007 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:31.617500 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:31.685634 [ 3012 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:31.701855 [ 3011 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:31.926030 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:32.078281 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:32.242668 [ 3027 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:32.687747 [ 3026 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:32.701188 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:32.703846 [ 3024 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:32.987582 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:33.142565 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:33.244924 [ 3031 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:33.689857 [ 3041 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:33.706168 [ 3040 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:33.804738 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:34.010712 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:34.199048 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:34.246868 [ 3048 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:34.385101 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:34.692451 [ 3057 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:34.708765 [ 3059 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:34.801246 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:35.023404 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:35.096771 [ 3621 ] {9daabd5f-04d9-4488-8f7c-b796f7cd863b} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:35.112416 [ 3621 ] {9daabd5f-04d9-4488-8f7c-b796f7cd863b} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:35.129077 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (61 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:35.248935 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:35.345646 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:35.695327 [ 3076 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:35.711445 [ 3073 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:35.832140 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:36.045544 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:36.250975 [ 3086 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:36.402069 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:36.697600 [ 3089 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:36.713462 [ 3093 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:36.810923 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:37.086138 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:37.252904 [ 3104 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:37.492925 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:37.699711 [ 3115 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:37.715555 [ 3113 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:37.827196 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:38.094977 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:38.255102 [ 3121 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:38.573462 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:38.701727 [ 3123 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:38.717500 [ 3128 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:38.864872 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:39.188251 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:39.256987 [ 3136 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:39.627182 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:39.627548 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:39.704229 [ 3146 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:39.719653 [ 3145 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:39.970623 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:40.259935 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:40.260025 [ 3152 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:40.370387 [ 3621 ] {2e79f392-8faa-431a-a4d0-66b12b6f5bd9} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:40.382383 [ 3621 ] {2e79f392-8faa-431a-a4d0-66b12b6f5bd9} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:40.457333 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (62 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:40.688946 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:40.706487 [ 3158 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:40.721950 [ 3161 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:40.997032 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:41.263597 [ 3171 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:41.274892 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:41.708844 [ 3172 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:41.724183 [ 3177 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:41.801322 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:42.016734 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:42.265702 [ 3185 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:42.309831 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:42.711480 [ 3192 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:42.727098 [ 3166 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:42.895737 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:43.061345 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:43.296182 [ 3198 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.332876 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:43.713599 [ 3205 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.729394 [ 3196 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:43.998726 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:44.097950 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:44.298139 [ 3210 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:44.323495 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:44.708419 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:44.717271 [ 3220 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:44.731313 [ 3221 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:45.056439 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:45.185226 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:45.300010 [ 3228 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:45.324387 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:45.668418 [ 3621 ] {be85ecca-002b-4cef-a8bd-fc4a8f48bdd6} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:45.671368 [ 3621 ] {be85ecca-002b-4cef-a8bd-fc4a8f48bdd6} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:45.694567 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (63 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:45.719283 [ 3229 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:45.733241 [ 3234 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:46.076277 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:46.242687 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:46.301952 [ 3248 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:46.367778 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:46.721343 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:46.735527 [ 3242 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:47.213514 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:47.257833 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:47.305519 [ 3259 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:47.394808 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:47.802297 [ 3262 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:47.806485 [ 3261 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:48.231718 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:48.289828 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:48.307951 [ 3271 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:48.411966 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:48.805034 [ 2774 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:48.808853 [ 3282 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:49.310201 [ 3280 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:49.342406 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:49.397629 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:49.502386 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:49.772722 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:49.807201 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:49.895717 [ 2787 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:50.342082 [ 2798 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:50.433768 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:50.480751 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:50.597434 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:50.809390 [ 2777 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:50.845078 [ 3621 ] {440ef21f-452a-4b57-ab49-73c2f9689939} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:50.848635 [ 3621 ] {440ef21f-452a-4b57-ab49-73c2f9689939} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:50.860312 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (64 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:50.898561 [ 2782 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:51.344474 [ 2813 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:51.493313 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:51.524955 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:51.654228 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:51.811803 [ 2811 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:51.905887 [ 2818 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:52.346630 [ 2821 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:52.546241 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:52.559307 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:52.690886 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:52.813744 [ 2833 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:52.908798 [ 2825 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:53.348499 [ 2828 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:53.646379 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:53.648132 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:53.764388 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:53.815707 [ 2844 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:53.911872 [ 2847 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:54.350552 [ 2856 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:54.675177 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:54.817824 [ 2863 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:54.837635 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:54.847615 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:54.865814 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:54.914398 [ 2861 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:55.357931 [ 2870 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:55.699816 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:55.819830 [ 2872 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:55.882733 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:55.884011 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:55.917562 [ 2871 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:56.106668 [ 3621 ] {81c5ce56-b3cd-4971-bb41-b04b54ee19dd} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:36:56.110585 [ 3621 ] {81c5ce56-b3cd-4971-bb41-b04b54ee19dd} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:56.131005 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (65 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:56.360581 [ 2879 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:56.760338 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:56.821825 [ 2885 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:56.904469 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:56.919926 [ 2888 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:57.022988 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:57.363795 [ 2896 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:57.779254 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:57.823976 [ 2901 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:57.924379 [ 2904 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:57.971188 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:58.084940 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:58.366386 [ 2902 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:58.869650 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:58.923327 [ 2914 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:58.927359 [ 2916 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:59.008571 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:59.125328 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:36:59.375998 [ 2923 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:59.925664 [ 2934 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:59.929546 [ 2933 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:59.939907 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:36:59.939854 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:00.090862 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:00.149614 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:00.377998 [ 2937 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:00.928728 [ 2951 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:00.931757 [ 2949 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:00.964456 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:01.144689 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:01.243809 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:01.316243 [ 3621 ] {dc244fa7-f54a-4d6f-a09f-4c90c125cc8f} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:01.327278 [ 3621 ] {dc244fa7-f54a-4d6f-a09f-4c90c125cc8f} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:01.348136 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (66 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:01.380519 [ 2953 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:01.930795 [ 2961 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:01.934007 [ 2957 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:01.990641 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:02.140972 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:02.286563 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:02.384857 [ 2968 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:02.932887 [ 2972 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:02.936237 [ 2973 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:03.018872 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:03.153155 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:03.313472 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:03.388056 [ 2982 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:03.935151 [ 2989 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:04.027393 [ 2993 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:04.057696 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:04.214447 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:04.338925 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:04.390026 [ 2997 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:04.941301 [ 3006 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:05.028967 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:05.029558 [ 3010 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:05.109358 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:05.297549 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:05.393248 [ 3009 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:05.426319 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:05.944024 [ 3018 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:06.032274 [ 3021 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:06.163629 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:06.353964 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:06.395748 [ 3014 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:06.513352 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:06.621994 [ 3621 ] {7729f0a8-3151-4ae9-9c00-bc18889d0a8b} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:06.624349 [ 3621 ] {7729f0a8-3151-4ae9-9c00-bc18889d0a8b} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:06.633769 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (67 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:06.946714 [ 3037 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:07.035099 [ 3039 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:07.199675 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:07.398030 [ 3047 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:07.423700 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:07.558060 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:07.949107 [ 3061 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:08.037235 [ 3052 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:08.199859 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:08.400166 [ 3068 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:08.449861 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:08.603075 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:08.951841 [ 3079 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:09.045655 [ 3074 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:09.239273 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:09.402107 [ 3085 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:09.509419 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:09.685625 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:09.954185 [ 3089 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:10.047696 [ 3093 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:10.165174 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:10.297042 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:10.404198 [ 3098 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:10.571307 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:10.699692 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:10.956711 [ 3100 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:11.050218 [ 3105 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:11.287287 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:11.406297 [ 3106 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:11.657020 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:11.767938 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:11.877208 [ 3621 ] {f0ec5520-2bf7-4bc9-b46a-b9b057523aa3} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:11.894534 [ 3621 ] {f0ec5520-2bf7-4bc9-b46a-b9b057523aa3} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:11.915453 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (68 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:11.958884 [ 3113 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:12.123609 [ 3120 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:12.365184 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:12.412228 [ 3124 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:12.707771 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:12.859704 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:12.961492 [ 3129 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:13.126046 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:13.414362 [ 3139 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:13.452154 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:13.816124 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:13.964519 [ 3144 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:14.018503 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:14.128342 [ 3154 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:14.417086 [ 3156 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:14.525476 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:14.898106 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:14.967312 [ 3162 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:15.073358 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:15.130826 [ 3160 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:15.276366 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:15.419328 [ 3167 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:15.592108 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:15.970141 [ 3185 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:15.971332 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:16.133015 [ 3188 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:16.151841 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:16.421423 [ 3175 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:16.642123 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:16.972008 [ 3193 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:16.996894 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:17.135237 [ 3197 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:17.176925 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:17.177282 [ 3621 ] {4149e1b0-caaf-4303-8395-af1d46708a88} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:17.180190 [ 3621 ] {4149e1b0-caaf-4303-8395-af1d46708a88} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:17.210591 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (69 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:17.423762 [ 3198 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:17.751857 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:18.007966 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:17.974226 [ 3209 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:18.137447 [ 3206 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:18.181269 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:18.426343 [ 3211 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:18.803576 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:19.007468 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:19.048304 [ 3220 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:19.139640 [ 3217 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:19.184982 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:19.428902 [ 3224 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:19.802202 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:20.050607 [ 3155 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:20.139743 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:20.142009 [ 3239 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:20.305564 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:20.360103 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:20.432226 [ 3249 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:20.808454 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:21.053253 [ 3251 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:21.139270 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:21.148420 [ 3243 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:21.338832 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:21.435594 [ 3255 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:21.976995 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:22.056015 [ 3262 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.150572 [ 3258 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.218484 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:22.424969 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:22.437874 [ 3264 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.625871 [ 3621 ] {e87ff5a7-9a91-4b39-9c40-128377bd5468} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:22.627680 [ 3621 ] {e87ff5a7-9a91-4b39-9c40-128377bd5468} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:22.636291 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (70 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:23.058064 [ 3278 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:23.083198 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:23.157547 [ 2774 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:23.260130 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:23.413399 [ 3677 ] {012abdc0-4ff7-43f3-b775-b69e258102f4} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53156) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:23.425632 [ 3677 ] {012abdc0-4ff7-43f3-b775-b69e258102f4} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:23.442791 [ 3279 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:23.535487 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:24.060128 [ 2781 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:24.090934 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:24.159553 [ 2796 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:24.285339 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:24.445026 [ 2792 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:24.761511 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:25.062249 [ 2799 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:25.082526 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:25.161429 [ 2805 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:25.300352 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:25.434578 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:25.447160 [ 2782 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:25.847192 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:26.064527 [ 2807 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:26.143640 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:26.163498 [ 2816 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:26.340304 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:26.449743 [ 2826 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:26.927468 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:27.066751 [ 2833 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:27.166183 [ 2834 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:27.185463 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:27.398380 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:27.476095 [ 2832 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:27.927957 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:28.044458 [ 3621 ] {34bc3ebc-e308-4777-85a4-cf60686d86e6} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:28.055939 [ 3621 ] {34bc3ebc-e308-4777-85a4-cf60686d86e6} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:28.068809 [ 2849 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:28.110455 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (71 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:28.168497 [ 2843 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:28.232615 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:28.420024 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:28.479408 [ 2850 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:28.484604 [ 3384 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_132_192_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:28.887442 [ 3390 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_132_192_12}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:28.936250 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:29.070882 [ 2866 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:29.170985 [ 2867 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:29.227987 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:29.444616 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:29.481512 [ 2871 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:30.017382 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:30.108568 [ 2880 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:30.173067 [ 2885 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:30.241047 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:30.483938 [ 2888 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:30.499430 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:30.544117 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:31.111271 [ 2898 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:31.175384 [ 2900 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:31.176548 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:31.381802 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:31.486316 [ 2901 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:31.718634 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:32.118388 [ 2902 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:32.177550 [ 2913 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:32.206924 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:32.447983 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:32.488445 [ 2917 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:32.772306 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:33.120213 [ 2920 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:33.179587 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:33.253431 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:33.329722 [ 3621 ] {d9f139eb-5d13-4020-a0c0-4168ad5d32ff} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:33.334394 [ 3621 ] {d9f139eb-5d13-4020-a0c0-4168ad5d32ff} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:33.357130 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (72 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:33.480120 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:33.491305 [ 2930 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:33.795893 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:34.122342 [ 2938 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:34.182083 [ 2939 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:34.353272 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:34.493786 [ 2944 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:34.508111 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:34.805860 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:35.124573 [ 2956 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:35.184308 [ 2955 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:35.430790 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:35.496108 [ 2960 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:35.591195 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:35.773601 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:35.855049 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:36.127440 [ 2972 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:36.186396 [ 2973 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:36.498486 [ 2978 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:36.504427 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:36.867535 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:36.907173 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:37.129629 [ 2990 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:37.189974 [ 2989 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:37.501024 [ 2992 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:37.599515 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:37.911274 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:37.934957 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:38.131868 [ 3002 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:38.192323 [ 3005 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:38.503236 [ 3008 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:38.691819 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:38.700632 [ 3621 ] {0d2e71f2-923e-46a5-8eb8-9465ab91ae15} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:38.715376 [ 3621 ] {0d2e71f2-923e-46a5-8eb8-9465ab91ae15} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:38.729548 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (73 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:38.937789 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:38.960503 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:39.133953 [ 3016 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:39.194819 [ 3019 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:39.505894 [ 3021 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:39.573565 [ 4049 ] {30193526-c0d6-494d-adb8-5d9bf3d6bf8f} executeQuery: Code: 181. DB::Exception: Storage MergeTree doesn't support FINAL. (ILLEGAL_FINAL) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38086) (comment: 00013_sorting_of_nested.sql) (in query: SELECT ParsedParams.Key1 FROM test.visits FINAL WHERE VisitID != 0 AND notEmpty(ParsedParams.Key1) ORDER BY VisitID LIMIT 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:832: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002836bff2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4f56 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 12. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:37:39.616393 [ 4049 ] {30193526-c0d6-494d-adb8-5d9bf3d6bf8f} TCPHandler: Code: 181. DB::Exception: Storage MergeTree doesn't support FINAL. (ILLEGAL_FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:832: DB::QueryAnalyzer::validateTableExpressionModifiers(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002836bff2 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4f56 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 9. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 12. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 13. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 15. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 16. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 17. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 18. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 20. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 21. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:37:39.808469 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:39.997823 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:40.007269 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:40.136370 [ 3035 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:40.197170 [ 3030 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:40.508369 [ 3029 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:40.734616 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:40.967371 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:41.063170 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:41.094316 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:41.138457 [ 3044 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:41.199231 [ 3049 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:41.543989 [ 3046 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:42.005372 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:42.076842 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:42.140595 [ 3059 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:42.200690 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:42.200964 [ 3061 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:42.546707 [ 3062 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:43.051996 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:43.142469 [ 3072 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:43.203071 [ 3077 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:43.225041 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:43.226498 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:43.548944 [ 3081 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:43.685581 [ 15589 ] {c48e481a-adbc-4809-adfb-e8fa20b461fa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38210) (comment: 00154_avro.sql) (in query: INSERT INTO test.avro SELECT * FROM test.hits LIMIT 10000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d362b87 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:37:43.729457 [ 15589 ] {c48e481a-adbc-4809-adfb-e8fa20b461fa} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 28. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d362b87 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:37:44.094998 [ 3621 ] {9da029e0-f9fb-4082-8174-9c0998270109} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:44.102354 [ 3621 ] {9da029e0-f9fb-4082-8174-9c0998270109} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:44.120007 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (74 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:44.146430 [ 3091 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:44.205140 [ 3094 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:44.239211 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:44.296501 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:44.299891 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:44.551885 [ 3103 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:45.148711 [ 3105 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:45.207548 [ 3111 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:45.302987 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:45.330975 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:45.456706 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:45.554529 [ 3115 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:45.924787 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:46.151324 [ 3126 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:46.209907 [ 3125 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:46.366155 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:46.388708 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:46.523291 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:46.557263 [ 3128 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:47.154011 [ 3138 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:47.212218 [ 3142 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:47.411986 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:47.450389 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:47.562380 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:47.568117 [ 3141 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:47.887221 [ 4049 ] {6883911b-b56b-4af0-bb3e-590f663e6279} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47714) (comment: 00082_quantiles.sql) (in query: SELECT CounterID AS k, quantilesTiming(0.1, 0.5, 0.9, 0.99, 0.999)(ResolutionWidth) FROM test.hits GROUP BY k ORDER BY count() DESC, CounterID LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:37:47.906720 [ 4049 ] {6883911b-b56b-4af0-bb3e-590f663e6279} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 28. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:37:48.156263 [ 3149 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:48.214327 [ 3152 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:48.447741 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:48.570694 [ 3159 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:48.595184 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:48.656041 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:48.702116 [ 3677 ] {271ef977-2a93-4134-abae-eeeba6e355e0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'Title' in scope SELECT DISTINCT Title, SearchPhrase FROM test.hits WHERE (SearchPhrase != '') AND (NOT match(Title, '[а-ÑÐ-ЯёÐ]')) AND (NOT match(SearchPhrase, '[а-ÑÐ-ЯёÐ]')) LIMIT 1 BY Title LIMIT 10. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47808) (comment: 00176_distinct_limit_by_limit_bug_43377.sql) (in query: SELECT count() FROM ( SELECT DISTINCT Title, SearchPhrase FROM test.hits WHERE (SearchPhrase != '') AND (NOT match(Title, '[а-ÑÐ-ЯёÐ]')) AND (NOT match(SearchPhrase, '[а-ÑÐ-ЯёÐ]')) LIMIT 1 BY Title LIMIT 10 );), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:37:48.733135 [ 3677 ] {271ef977-2a93-4134-abae-eeeba6e355e0} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'Title' in scope SELECT DISTINCT Title, SearchPhrase FROM test.hits WHERE (SearchPhrase != '') AND (NOT match(Title, '[а-ÑÐ-ЯёÐ]')) AND (NOT match(SearchPhrase, '[а-ÑÐ-ЯёÐ]')) LIMIT 1 BY Title LIMIT 10. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:37:49.158546 [ 3165 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:49.216851 [ 3160 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:49.543739 [ 3621 ] {4568019e-e154-4c20-9980-63b032c9ca40} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:49.548822 [ 3621 ] {4568019e-e154-4c20-9980-63b032c9ca40} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:49.565965 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (75 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:49.578025 [ 3172 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:49.593551 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:49.608120 [ 15589 ] {d578f872-6c81-42e1-bee3-4868a349e40e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT arrayJoin([SearchEngineID]) AS search_engine, URL FROM test.hits WHERE (SearchEngineID != 0) AND (search_engine != 0). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47820) (comment: 00093_prewhere_array_join.sql) (in query: SELECT arrayJoin([SearchEngineID]) AS search_engine, URL FROM test.hits WHERE SearchEngineID != 0 AND search_engine != 0 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:37:49.620181 [ 15589 ] {d578f872-6c81-42e1-bee3-4868a349e40e} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'URL' in scope SELECT arrayJoin([SearchEngineID]) AS search_engine, URL FROM test.hits WHERE (SearchEngineID != 0) AND (search_engine != 0). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:37:49.740434 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:49.888884 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:50.160948 [ 3182 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:50.221975 [ 3185 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:50.441641 [ 3382 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c1299da-d909-4b7c-85cc-168a8083c3c9::202510_1_95_19}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:50.580146 [ 3192 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:50.672256 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:50.822170 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:51.040071 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:51.093505 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:51.163578 [ 3202 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:51.224255 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:51.288213 [ 15589 ] {dc253590-d20f-4a0b-bd62-e8f3e2ea5856} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 181 and result: 133). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47856) (comment: 00152_insert_different_granularity.sql) (in query: INSERT INTO fixed_granularity_table SELECT * FROM test.hits LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7d4ba 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x00000000282762a6 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000029363ec3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:37:51.312423 [ 15589 ] {dc253590-d20f-4a0b-bd62-e8f3e2ea5856} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 181 and result: 133). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7d4ba 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x00000000282762a6 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000029363ec3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:37:51.582288 [ 3210 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:51.833936 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:52.139272 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:52.166234 [ 3218 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:52.226586 [ 3222 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:52.483975 [ 15589 ] {ad5952db-897f-437b-8ff9-5516be4212cc} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'WatchID' in scope 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 ASC, WatchID ASC. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47898) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3951: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bb8e0 6. ./contrib/llvm-project/libcxx/include/vector:432: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283660cc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 15. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:37:52.513428 [ 15589 ] {ad5952db-897f-437b-8ff9-5516be4212cc} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'WatchID' in scope 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 ASC, WatchID ASC. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3951: DB::QueryAnalyzer::resolveSortNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283bb8e0 6. ./contrib/llvm-project/libcxx/include/vector:432: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283660cc 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 12. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 15. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 16. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 18. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 19. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 20. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 21. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 23. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 24. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:37:52.584682 [ 3227 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:52.968845 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:53.168702 [ 3248 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:53.236931 [ 3241 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:53.271548 [ 16283 ] {3a630989-9637-43fa-8460-596738a17841} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT min(EventDate), max(EventDate) FROM test.hits. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47944) (comment: 00048_min_max.sql) (in query: SELECT min(EventDate), max(EventDate) FROM test.hits ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:37:53.275948 [ 16283 ] {3a630989-9637-43fa-8460-596738a17841} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT min(EventDate), max(EventDate) FROM test.hits. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:37:53.320817 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:53.401661 [ 15589 ] {1fb21602-87b2-42f8-a2a6-ded5c632b11a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47920) (comment: 03011_definitive_guide_to_cast.sql) (in query: -- It converts between various data types, including parameterized data types SELECT CAST(1234567890 AS DateTime('Europe/Amsterdam'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000029111a87 7. ./build_docker/./src/Interpreters/ExternalLoader.cpp:928: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x0000000029109a37 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x0000000029132f5d 9. ./contrib/llvm-project/libcxx/include/__mutex_base:203: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x0000000029131bf2 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000291361ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:37:53.407070 [ 15589 ] {1fb21602-87b2-42f8-a2a6-ded5c632b11a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000029111a87 7. ./build_docker/./src/Interpreters/ExternalLoader.cpp:928: DB::ExternalLoader::LoadingDispatcher::startLoading(DB::ExternalLoader::LoadingDispatcher::Info&, bool, unsigned long) @ 0x0000000029109a37 8. ./build_docker/./src/Interpreters/ExternalLoader.cpp:702: DB::ExternalLoader::LoadingDispatcher::reloadOutdated() @ 0x0000000029132f5d 9. ./contrib/llvm-project/libcxx/include/__mutex_base:203: DB::ExternalLoader::PeriodicUpdater::doPeriodicUpdates() @ 0x0000000029131bf2 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000291361ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:37:53.660802 [ 3251 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:54.054425 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:54.171501 [ 3257 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:54.239052 [ 3262 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:54.346128 [ 3387 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6d7bfeba-2878-4bef-86bb-b5da6ac05b55::202510_1_101_20}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:54.361457 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:54.663032 [ 3274 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:54.755068 [ 3621 ] {1e7d0792-471c-44ee-a217-035abeee2945} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:37:54.758232 [ 3621 ] {1e7d0792-471c-44ee-a217-035abeee2945} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:54.770310 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (76 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.106424 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:55.176296 [ 3279 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.241841 [ 2775 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:55.523979 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:55.665937 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:56.178933 [ 2798 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:56.225507 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:56.237702 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:56.244348 [ 2790 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:56.602569 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:56.668615 [ 2789 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:57.180917 [ 2793 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:57.250174 [ 2797 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:57.289345 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:57.671816 [ 2819 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:57.689585 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:58.183354 [ 2830 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:58.253016 [ 2823 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:58.432402 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:58.674506 [ 2835 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:58.745765 [ 15589 ] {d74a0e1f-86ef-4bb1-be92-c71bc2878f10} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:46152) (comment: 02521_cannot_find_column_in_projection.sql) (in query: DROP DATABASE IF EXISTS test_lgpq707d ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:37:58.755047 [ 15589 ] {d74a0e1f-86ef-4bb1-be92-c71bc2878f10} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:58.870013 [ 2840 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286d17dc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286d20a6 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:58.901444 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:59.185639 [ 2846 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:59.264682 [ 2851 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:37:59.498706 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:37:59.677141 [ 2848 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:00.008430 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:00.042864 [ 3621 ] {29ca6f95-c521-427d-8868-300dd8fd7212} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:00.047279 [ 3621 ] {29ca6f95-c521-427d-8868-300dd8fd7212} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:00.063205 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (77 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:00.187880 [ 2864 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:00.267405 [ 2870 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:00.587427 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:00.679376 [ 2876 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:01.105312 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:01.190189 [ 2885 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:01.269288 [ 2888 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:01.327304 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:01.669119 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:01.681480 [ 2895 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:02.192290 [ 2907 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:02.271508 [ 2910 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:02.297767 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:02.684000 [ 2918 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:02.709573 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:03.194520 [ 2927 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:03.274082 [ 2931 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:03.518937 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:03.686860 [ 2932 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:03.750411 [ 8268 ] {402f63b3-3fe0-425d-ba63-64ab4468c827} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=725). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40152) (comment: 02809_has_subsequence.sql) (in query: select hasSubsequence('garbage', 'garbage');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:03.754170 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:03.754383 [ 8268 ] {402f63b3-3fe0-425d-ba63-64ab4468c827} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=725). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:04.202834 [ 2940 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:04.276508 [ 2943 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:04.605025 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:04.690342 [ 2959 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:04.858445 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:05.206033 [ 2961 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:05.278852 [ 2967 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:05.373992 [ 3621 ] {f8d169d4-47e0-4e69-9e8e-8f9f20791d43} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:05.382318 [ 3621 ] {f8d169d4-47e0-4e69-9e8e-8f9f20791d43} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:05.411782 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (78 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:05.692440 [ 2973 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:05.695511 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:05.899123 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:06.208378 [ 2984 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:06.281513 [ 2985 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:06.411852 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:06.697405 [ 2995 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:06.766416 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:06.942233 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:07.210733 [ 3004 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:07.283718 [ 3005 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:07.704001 [ 3012 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:07.965464 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:08.040757 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:08.213233 [ 3024 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:08.291028 [ 3033 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:08.706993 [ 3031 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:09.088175 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:09.165099 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:09.215683 [ 3044 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:09.293129 [ 3047 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:09.715640 [ 3053 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:10.157409 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:10.207307 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:10.217974 [ 3060 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:10.295175 [ 3052 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:10.613958 [ 3621 ] {70373cc2-0837-4cad-8c4a-89d11ead56ef} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:10.617903 [ 3621 ] {70373cc2-0837-4cad-8c4a-89d11ead56ef} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:10.629705 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (79 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:10.718519 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:11.220001 [ 3080 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:11.272851 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:11.297431 [ 3083 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:11.318477 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:11.503343 [ 16283 ] {905ed383-1296-47f8-a941-2b38f1667a5e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58956) (comment: 02946_materialize_column_must_not_override_past_values.sql) (in query: SELECT * FROM tab ORDER BY id;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:11.510120 [ 16283 ] {905ed383-1296-47f8-a941-2b38f1667a5e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:11.525634 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:11.721183 [ 3088 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:12.222229 [ 3098 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:12.299572 [ 3099 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:12.348576 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:12.408600 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:12.723507 [ 3107 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:13.231273 [ 3113 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:13.301551 [ 3117 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:13.385562 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:13.526934 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:13.725805 [ 3125 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:14.234029 [ 3134 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:14.304212 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:14.570054 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:14.728099 [ 3146 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:14.829122 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:15.236434 [ 3157 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:15.307409 [ 3164 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:15.317553 [ 3677 ] {781dba07-8648-4bf4-a846-a750d91dc052} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47966) (comment: 00148_monotonic_functions_and_index.sql) (in query: SELECT count() FROM test.hits WHERE -CounterID > -732797 AND CounterID >= 107931;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:15.324675 [ 3677 ] {781dba07-8648-4bf4-a846-a750d91dc052} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:15.634002 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:15.737043 [ 3172 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:15.912216 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:15.950907 [ 3621 ] {c5b53ff5-b6f2-470c-8262-4bc76bebcc01} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:15.960596 [ 3621 ] {c5b53ff5-b6f2-470c-8262-4bc76bebcc01} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:16.003024 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (80 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:16.047104 [ 8268 ] {b1faeee0-b304-4112-91c8-0faba30e487c} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT CAST(EventTime, 'DateTime(\'Asia/Dubai\')') FROM test.hits ORDER BY EventTime DESC LIMIT 10. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56090) (comment: 00011_sorting.sql) (in query: SELECT EventTime::DateTime('Asia/Dubai') FROM test.hits ORDER BY EventTime DESC LIMIT 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:16.062716 [ 8268 ] {b1faeee0-b304-4112-91c8-0faba30e487c} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT CAST(EventTime, 'DateTime(\'Asia/Dubai\')') FROM test.hits ORDER BY EventTime DESC LIMIT 10. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:16.239098 [ 3183 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:16.309542 [ 3187 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:16.686972 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:16.700986 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:16.739260 [ 3190 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:16.920978 [ 8268 ] {0f8451cb-d1b6-4825-b7c8-365702b3587e} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.visits WHERE CounterID IN (942285, 577322). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56098) (comment: 00021_2_select_with_in.sql) (in query: select sum(Sign) from test.visits where CounterID in (942285, 577322);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:16.925338 [ 8268 ] {0f8451cb-d1b6-4825-b7c8-365702b3587e} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.visits WHERE CounterID IN (942285, 577322). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:17.064797 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:17.241558 [ 3202 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:17.312064 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:17.741902 [ 16283 ] {4733c5c1-633a-4571-99ad-0624ed395852} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.visits WHERE CounterID IN (942285). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56112) (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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:17.742719 [ 3211 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:17.758856 [ 16283 ] {4733c5c1-633a-4571-99ad-0624ed395852} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT sum(Sign) FROM test.visits WHERE CounterID IN (942285). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:18.200825 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:18.244119 [ 3218 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:18.314477 [ 3220 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:18.745201 [ 3231 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:19.246613 [ 3238 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:19.252111 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:19.316529 [ 3241 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:19.706086 [ 16283 ] {43818d29-9cb2-4391-ba23-23648bc814ad} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=726). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56132) (comment: 02503_cache_on_write_with_small_segment_size.sh) (in query: insert into ttt select number, toString(number) from numbers(100000) settings throw_on_error_from_cache_on_write_operations = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d361ab7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d192da3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:38:19.709760 [ 16283 ] {43818d29-9cb2-4391-ba23-23648bc814ad} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=726). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d361ab7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d192da3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:38:19.756380 [ 3251 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:20.248913 [ 3259 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:20.318806 [ 3260 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:20.393382 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:20.759210 [ 3275 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:21.251230 [ 3270 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:21.320923 [ 2791 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:21.356453 [ 8268 ] {3db0052e-63dd-457b-9e56-6101a7739cc0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56202) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format TSVWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:21.357922 [ 3621 ] {10dd3f45-631b-4430-8e84-d5362bc2593e} executeQuery: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:21.366767 [ 3621 ] {10dd3f45-631b-4430-8e84-d5362bc2593e} DDLWorker(test_1_repl_01111_14): Query /* ddl_entry=query-0000000003 */ CREATE TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UUID '7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd' (`n` Int32) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271 wasn't finished successfully: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 12. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 13. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:21.376302 [ 8268 ] {3db0052e-63dd-457b-9e56-6101a7739cc0} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:21.395816 [ 3621 ] {} DDLWorker(test_1_repl_01111_14): Unexpected error (81 times in a row), will try to restart main thread: Code: 341. DB::Exception: Unexpected error: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)). (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&) @ 0x000000000ab00574 4. ./build_docker/./src/Interpreters/DDLWorker.cpp:683: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868e6b5 5. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688f86 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:21.613247 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:21.762441 [ 2788 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:21.805300 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:22.253451 [ 2799 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:22.323110 [ 2780 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:22.670017 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:22.764523 [ 2797 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:23.277736 [ 2816 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:23.325619 [ 2821 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:23.766906 [ 2829 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:23.799694 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:24.093439 [ 15589 ] {61a8d654-0f4f-470c-9ca5-ecb58230830a} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56204) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format TSVWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:24.109473 [ 4147 ] {1ddfc505-c18a-4ba0-8f8a-527bebde96b9} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39072) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:24.112299 [ 4147 ] {1ddfc505-c18a-4ba0-8f8a-527bebde96b9} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:24.136630 [ 15589 ] {61a8d654-0f4f-470c-9ca5-ecb58230830a} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:24.279862 [ 2841 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:24.337904 [ 2842 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:24.769018 [ 2847 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:24.904520 [ 15589 ] {54af611c-3f1b-4941-9d1b-76550337e12b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56234) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_1_repl_01111_11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:24.920017 [ 15589 ] {54af611c-3f1b-4941-9d1b-76550337e12b} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:24.933428 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:25.282717 [ 2857 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:25.340054 [ 2858 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:25.771804 [ 2859 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:25.777717 [ 3677 ] {cc3bc352-73c9-4cb7-b77d-03776888913b} executeQuery: Code: 57. DB::Exception: Table test_yihk30k4.test_aggregation already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56290) (comment: 01768_array_product.sql) (in query: CREATE TABLE test_aggregation (x Array(Decimal64(8))) ENGINE=TinyLog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:25.792559 [ 3677 ] {cc3bc352-73c9-4cb7-b77d-03776888913b} TCPHandler: Code: 57. DB::Exception: Table test_yihk30k4.test_aggregation already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:25.918430 [ 2864 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:26.109137 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:26.284983 [ 2873 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:26.342523 [ 2871 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:26.397959 [ 16283 ] {7efca1e1-438e-4d9a-a8b5-f335923bae7a} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56292) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:26.412032 [ 16283 ] {7efca1e1-438e-4d9a-a8b5-f335923bae7a} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:26.774042 [ 2882 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:26.922163 [ 2886 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:26.988296 [ 3790 ] {} DDLWorker(test_1_repl_01111_4): Error on initialization of test_1_repl_01111_4: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:27.160389 [ 16283 ] {d8d4543f-a207-43c6-9d76-fe6595aa92c0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56300) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format CSVWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:27.171122 [ 16283 ] {d8d4543f-a207-43c6-9d76-fe6595aa92c0} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:27.214499 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:27.296440 [ 2887 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:27.345140 [ 2888 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:27.776373 [ 2897 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:27.924538 [ 2901 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:28.300747 [ 2910 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:28.348126 [ 2802 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:28.360109 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:28.778970 [ 2918 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:28.926668 [ 2923 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:29.248277 [ 16283 ] {c4eeede2-c4dd-4e6d-a66d-d74f9202b18f} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56382) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:29.255487 [ 16283 ] {c4eeede2-c4dd-4e6d-a66d-d74f9202b18f} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:29.303329 [ 2931 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:29.350666 [ 2934 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:29.599945 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:29.781173 [ 2944 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:29.929217 [ 2951 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:30.012844 [ 8268 ] {f0b0687b-3e02-49b9-bef5-582129b2970e} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56400) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format CSVWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:30.032029 [ 8268 ] {f0b0687b-3e02-49b9-bef5-582129b2970e} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:30.305865 [ 2956 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:30.352992 [ 2955 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:30.730985 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:30.783482 [ 2960 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:30.932717 [ 2963 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:31.308241 [ 2964 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:31.357510 [ 2974 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:31.785684 [ 2983 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:31.835186 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:31.936438 [ 2988 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.309920 [ 8268 ] {ab4c9d51-13bc-45d8-b2f7-1a053f82c59f} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56492) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:32.318354 [ 2990 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.325016 [ 8268 ] {ab4c9d51-13bc-45d8-b2f7-1a053f82c59f} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:32.359684 [ 2986 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.787660 [ 3001 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:32.932689 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:32.938917 [ 3006 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:33.041589 [ 4147 ] {5cb93eeb-567f-4837-bb45-62affdb78d38} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56510) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONStringsEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:33.064192 [ 4147 ] {5cb93eeb-567f-4837-bb45-62affdb78d38} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:33.320641 [ 3005 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:33.361637 [ 3007 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:33.797001 [ 3020 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:33.942929 [ 3018 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:33.963922 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:34.324355 [ 3022 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:34.366321 [ 3033 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:34.386861 [ 16283 ] {026cd355-1432-4fc4-8021-9fdd0d7d1b31} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=720). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56450) (comment: 00803_xxhash.sql) (in query: select xxHash64(toUInt64(0)) = xxHash64('\0\0\0\0\0\0\0\0');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:34.390712 [ 16283 ] {026cd355-1432-4fc4-8021-9fdd0d7d1b31} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=720). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:34.539252 [ 17479 ] {450438d2-93a3-44d7-8458-13279439711f} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:a1bbf453-69b0-47bc-b576-1b68e93083c0'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57902) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_7 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:34.550481 [ 17479 ] {450438d2-93a3-44d7-8458-13279439711f} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:a1bbf453-69b0-47bc-b576-1b68e93083c0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:34.798949 [ 3028 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:34.945155 [ 3038 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:35.052470 [ 4049 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:35.283215 [ 3677 ] {410dd42a-d251-4b72-baf5-7f7e2c13f26d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57946) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1_repl_01111_11.rmt_15100_11738_19605 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:35.292158 [ 3677 ] {410dd42a-d251-4b72-baf5-7f7e2c13f26d} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:35.310985 [ 15589 ] {c7a33e90-612e-4529-b9d7-6b9533210774} executeQuery: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57958) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:35.313647 [ 15589 ] {c7a33e90-612e-4529-b9d7-6b9533210774} TCPHandler: Code: 57. DB::Exception: Table test_9.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:35.313591 [ 4147 ] {3b3c7f51-2e23-4668-9801-ae368e8d2ffe} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57932) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_9309_9242_30533 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:38:35.327013 [ 3043 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:35.333647 [ 4147 ] {3b3c7f51-2e23-4668-9801-ae368e8d2ffe} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:38:35.368518 [ 3048 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:35.772086 [ 9631 ] {} DDLWorker(test_1_repl_01111_14): Error on initialization of test_1_repl_01111_14: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:35.800838 [ 3058 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:35.949469 [ 3059 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:36.004896 [ 17479 ] {92aedec4-35b9-4587-a4d1-381c1d042791} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58004) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONStringsEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:36.030757 [ 17479 ] {92aedec4-35b9-4587-a4d1-381c1d042791} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:36.125224 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:36.330763 [ 3070 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:36.374251 [ 3072 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:36.383649 [ 17479 ] {b176ac16-d45f-4ce7-a5e8-9804208e92d4} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT count() FROM test.hits WHERE NOT ((EventDate >= toDate('2015-01-01')) AND (EventDate < toDate('2015-02-01'))). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58074) (comment: 00055_index_and_not.sql) (in query: SELECT count() FROM test.hits WHERE NOT (EventDate >= toDate('2015-01-01') AND EventDate < toDate('2015-02-01')) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:38:36.429006 [ 17479 ] {b176ac16-d45f-4ce7-a5e8-9804208e92d4} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT count() FROM test.hits WHERE NOT ((EventDate >= toDate('2015-01-01')) AND (EventDate < toDate('2015-02-01'))). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:38:36.807011 [ 3083 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:36.901186 [ 8268 ] {73daea22-601a-4cec-8caf-41a2adb8ff5d} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58096) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:36.914611 [ 8268 ] {73daea22-601a-4cec-8caf-41a2adb8ff5d} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:36.951839 [ 3085 ] {} test_1_repl_01111_11.rmt_15100_11738_19605 (7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:37.048285 [ 4227 ] {} DDLWorker(test_1_repl_01111_15): Error on initialization of test_1_repl_01111_15: Code: 57. DB::Exception: Directory for table data store/7a1/7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:37.061817 [ 3677 ] {1f71121c-66dd-4adc-87e8-3a4a09654050} executeQuery: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58126) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.local_01099_b update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:37.087044 [ 3677 ] {1f71121c-66dd-4adc-87e8-3a4a09654050} TCPHandler: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:37.225128 [ 8268 ] {12dd6605-3805-433d-b70b-8808b0d85fd5} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT min(EventDate), max(EventDate) FROM test.hits. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58128) (comment: 00048_min_max.sql) (in query: SELECT min(EventDate), max(EventDate) FROM test.hits ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:37.259422 [ 8268 ] {12dd6605-3805-433d-b70b-8808b0d85fd5} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventDate' in scope SELECT min(EventDate), max(EventDate) FROM test.hits. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:37.280421 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:37.335225 [ 3094 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:37.380136 [ 3095 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:37.809415 [ 3108 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:38.051745 [ 17481 ] {c3779075-bb80-4395-ba4a-09c421357944} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT CounterID % 100000 AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58170) (comment: 00074_full_join.sql) (in query: SELECT CounterID, hits, visits FROM ( SELECT (CounterID % 100000) AS CounterID, count() AS hits FROM test.hits GROUP BY CounterID ) ANY FULL OUTER JOIN ( SELECT (CounterID % 100000) AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0 ) USING CounterID WHERE hits = 0 OR visits = 0 ORDER BY hits + visits * 10 DESC, CounterID ASC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 13. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c85ac 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4eee 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:38.070483 [ 17481 ] {c3779075-bb80-4395-ba4a-09c421357944} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT CounterID % 100000 AS CounterID, sum(Sign) AS visits FROM test.visits GROUP BY CounterID HAVING visits > 0. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 13. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c85ac 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4eee 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:38.337042 [ 3117 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:38.388869 [ 3118 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:38.412166 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:38.472894 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Mapping for table with UUID=7a15853f-ce0d-4cb1-a6c1-c61b580f8fcd already exists. It happened due to UUID collision, most likely because some not random UUIDs were manually specified in CREATE queries. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception, DB::UUIDTag> const&>(int, FormatStringHelperImpl, DB::UUIDTag> const&>::type>, StrongTypedef, DB::UUIDTag> const&) @ 0x0000000027d0d2f4 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:779: DB::DatabaseCatalog::addUUIDMapping(StrongTypedef, DB::UUIDTag> const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x00000000286becbd 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseCatalog::addUUIDMapping(StrongTypedef, DB::UUIDTag> const&) @ 0x00000000286b1a03 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c5785 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 9. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 10. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 12. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 13. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 14. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:38.760042 [ 15589 ] {f8be5ab7-ff65-40ed-a0f0-7d73de2d76cd} executeQuery: Code: 60. DB::Exception: Table default.local_table_2 does not exist. Maybe you meant test_11.local_table_2?. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58240) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: insert into test_11.distributed_table_2 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000002c22504a 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x000000002c217ffd 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000002c215a79 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbfe1ce 13. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9de3da 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9ddef1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9dd046 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d1a6573 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192b98 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:38.772421 [ 15589 ] {f8be5ab7-ff65-40ed-a0f0-7d73de2d76cd} TCPHandler: Code: 60. DB::Exception: Table default.local_table_2 does not exist. Maybe you meant test_11.local_table_2?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeToLocal(DB::Cluster::ShardInfo const&, DB::Block const&, unsigned long) @ 0x000000002c22504a 10. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::writeAsyncImpl(DB::Block const&, unsigned long) @ 0x000000002c217ffd 11. ./build_docker/./src/Storages/Distributed/DistributedSink.cpp:0: DB::DistributedSink::consume(DB::Chunk&) @ 0x000000002c215a79 12. ./build_docker/./src/Processors/Sinks/SinkToStorage.cpp:11: DB::SinkToStorage::onConsume(DB::Chunk) @ 0x000000002dbfe1ce 13. ./contrib/llvm-project/libcxx/include/vector:432: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d9de3da 14. ./build_docker/./src/Processors/Transforms/ExceptionKeepingTransform.cpp:102: DB::runStep(std::function, DB::ThreadStatus*, std::atomic*) @ 0x000000002d9ddef1 15. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d9dd046 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 18. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 19. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processInsertQuery() @ 0x000000002d1a6573 20. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192b98 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:38.903346 [ 3130 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:38.986838 [ 8268 ] {92412878-7b4d-4f7a-b6d3-cc795cb87be3} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 32152608. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58266) (comment: 00024_random_counters.sql) (in query: SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 32152608;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.003215 [ 8268 ] {92412878-7b4d-4f7a-b6d3-cc795cb87be3} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Sign' in scope SELECT uniq(UserID), sum(Sign) FROM test.visits WHERE CounterID = 32152608. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.097270 [ 17481 ] {9a2250b1-f06d-40ce-85c0-ed125350a018} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cab7b52c-e3bd-4dbc-81d1-e37ec810634f', current host ID: '793cd66ee8bf:9000:9637b74f-6ee3-48bd-8764-39857ac40de7'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58278) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_12 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.115124 [ 15589 ] {8767eb8c-569b-48ce-a6a2-340d7cce02ad} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58286) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.test_table update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.123012 [ 15589 ] {8767eb8c-569b-48ce-a6a2-340d7cce02ad} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.129755 [ 17481 ] {9a2250b1-f06d-40ce-85c0-ed125350a018} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cab7b52c-e3bd-4dbc-81d1-e37ec810634f', current host ID: '793cd66ee8bf:9000:9637b74f-6ee3-48bd-8764-39857ac40de7'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.339245 [ 3137 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:39.444591 [ 3136 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:39.486376 [ 17481 ] {2665bcd8-c218-47ec-b9e1-f4baef75b854} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58324) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.523737 [ 17481 ] {2665bcd8-c218-47ec-b9e1-f4baef75b854} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.526692 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.905964 [ 3158 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:39.953361 [ 15589 ] {325b3a10-4de7-4ea6-849d-090ede869c24} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cf1e91d0-ab82-42d0-b95f-7762d42a4c4a', current host ID: '793cd66ee8bf:9000:5cc67c48-6a8b-49e0-ba6c-ab577aa857f9'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58392) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_10 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:39.987963 [ 15589 ] {325b3a10-4de7-4ea6-849d-090ede869c24} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cf1e91d0-ab82-42d0-b95f-7762d42a4c4a', current host ID: '793cd66ee8bf:9000:5cc67c48-6a8b-49e0-ba6c-ab577aa857f9'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.166370 [ 4049 ] {7617fb0f-f50b-49db-8e33-9f5cea6a6022} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58412) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.234228 [ 4049 ] {7617fb0f-f50b-49db-8e33-9f5cea6a6022} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.269352 [ 17481 ] {412596c4-5b64-4649-942a-ba1e98d34b49} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'PredLastVisit' in scope SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58376) (comment: 00020_distinct_order_by_distributed.sql) (in query: SELECT count() FROM (SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.306069 [ 17481 ] {412596c4-5b64-4649-942a-ba1e98d34b49} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'PredLastVisit' in scope SELECT DISTINCT PredLastVisit AS x FROM remote('127.0.0.{1,2}', test, visits) ORDER BY VisitID ASC. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.349677 [ 3163 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:40.458427 [ 3170 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:40.542504 [ 4147 ] {d2da1c1b-e497-4b99-99ac-e2d79e11d903} executeQuery: Code: 20. DB::Exception: Number of columns doesn't match (source: 181 and result: 133). (NUMBER_OF_COLUMNS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58228) (comment: 00152_insert_different_granularity.sql) (in query: INSERT INTO fixed_granularity_table SELECT * FROM test.hits LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7d4ba 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x00000000282762a6 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000029363ec3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.639641 [ 3677 ] {bf795562-83c3-4890-b10c-0f2d88996016} executeQuery: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58434) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: insert into test_11.dist_02346 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/StorageDistributed.cpp:913: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b74100a 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293667b0 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:794: DB::InterpreterInsertQuery::execute() @ 0x0000000029369e59 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.656484 [ 4147 ] {d2da1c1b-e497-4b99-99ac-e2d79e11d903} TCPHandler: Code: 20. DB::Exception: Number of columns doesn't match (source: 181 and result: 133). (NUMBER_OF_COLUMNS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7d4ba 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1464: DB::ActionsDAG::makeConvertingActions(std::vector> const&, std::vector> const&, DB::ActionsDAG::MatchColumnsMode, bool, bool, std::unordered_map, std::equal_to, std::allocator>>*) @ 0x00000000282762a6 5. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:544: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x0000000029363ec3 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.681855 [ 3677 ] {bf795562-83c3-4890-b10c-0f2d88996016} TCPHandler: Code: 55. DB::Exception: Method write is not supported by storage Distributed with more than one shard and no sharding key provided. (STORAGE_REQUIRES_PARAMETER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/StorageDistributed.cpp:913: DB::StorageDistributed::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x000000002b74100a 5. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 6. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293667b0 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:794: DB::InterpreterInsertQuery::execute() @ 0x0000000029369e59 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.693115 [ 17627 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.880379 [ 4049 ] {66c46bbc-2933-41ab-b92a-46c2fb6402b9} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cf1e91d0-ab82-42d0-b95f-7762d42a4c4a', current host ID: '793cd66ee8bf:9000:a2a9dfbb-f429-4563-8799-ccda568dc48a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58496) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_6 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.892279 [ 4049 ] {66c46bbc-2933-41ab-b92a-46c2fb6402b9} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cf1e91d0-ab82-42d0-b95f-7762d42a4c4a', current host ID: '793cd66ee8bf:9000:a2a9dfbb-f429-4563-8799-ccda568dc48a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:40.908039 [ 3184 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:41.016712 [ 3677 ] {820cc83b-00b3-45ae-b436-8f1f44eb644c} executeQuery: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58504) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.distributed_01099_b update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:41.027967 [ 3677 ] {820cc83b-00b3-45ae-b436-8f1f44eb644c} TCPHandler: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:41.353265 [ 3192 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:41.460438 [ 3193 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:41.858622 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:41.911077 [ 3211 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:41.931387 [ 4147 ] {81c0e61d-2b47-4940-b48b-c4c129141937} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:bc4218bc-a34c-4204-974a-cc6d94163f09', current host ID: '793cd66ee8bf:9000:ae22f068-c673-420b-8fb1-912c2de3eeb6'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58566) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_10 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:41.979548 [ 4147 ] {81c0e61d-2b47-4940-b48b-c4c129141937} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:bc4218bc-a34c-4204-974a-cc6d94163f09', current host ID: '793cd66ee8bf:9000:ae22f068-c673-420b-8fb1-912c2de3eeb6'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:42.355622 [ 3221 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:42.380815 [ 4049 ] {c846558e-9db9-4809-9143-c5d689b5e413} executeQuery: Code: 36. DB::Exception: Object in bucket test with key test_02245 already exists. If you want to overwrite it, enable setting s3_truncate_on_insert, if you want to create a new file on each insert, enable setting s3_create_new_file_on_insert. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58622) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: insert into test_1.test_02245 values ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&, String&&) @ 0x0000000026822de6 4. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:38: DB::checkAndGetNewFileOnInsertIfNeeded(DB::IObjectStorage const&, DB::StorageObjectStorage::Configuration const&, DB::StorageObjectStorage::QuerySettings const&, String const&, unsigned long) @ 0x0000000026821516 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000267be474 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293667b0 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:794: DB::InterpreterInsertQuery::execute() @ 0x0000000029369e59 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:38:42.394482 [ 4049 ] {c846558e-9db9-4809-9143-c5d689b5e413} TCPHandler: Code: 36. DB::Exception: Object in bucket test with key test_02245 already exists. If you want to overwrite it, enable setting s3_truncate_on_insert, if you want to create a new file on each insert, enable setting s3_create_new_file_on_insert. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String const&, String&&, String&&) @ 0x0000000026822de6 4. ./build_docker/./src/Storages/ObjectStorage/Utils.cpp:38: DB::checkAndGetNewFileOnInsertIfNeeded(DB::IObjectStorage const&, DB::StorageObjectStorage::Configuration const&, DB::StorageObjectStorage::QuerySettings const&, String const&, unsigned long) @ 0x0000000026821516 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::StorageObjectStorage::write(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, bool) @ 0x00000000267be474 6. ./build_docker/./src/Processors/Transforms/buildPushingToViewsChain.cpp:573: DB::buildPushingToViewsChain(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr const&, bool, std::shared_ptr, std::shared_ptr, std::atomic*, bool, DB::Block const&) @ 0x000000002db8c4f2 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:342: DB::InterpreterInsertQuery::buildSink(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::atomic*) @ 0x000000002935f11f 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:427: DB::InterpreterInsertQuery::buildPreAndSinkChains(unsigned long, unsigned long, std::shared_ptr, std::shared_ptr const&, DB::Block const&) @ 0x0000000029360ec1 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:678: DB::InterpreterInsertQuery::buildInsertPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x00000000293667b0 10. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:794: DB::InterpreterInsertQuery::execute() @ 0x0000000029369e59 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:38:42.463040 [ 3224 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:42.526702 [ 8268 ] {0a1924c0-1c6b-4e93-bb47-445264823ae6} executeQuery: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_3: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58534) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1_repl_01111_3), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:42.538484 [ 8268 ] {0a1924c0-1c6b-4e93-bb47-445264823ae6} TCPHandler: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_3: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:42.583027 [ 15589 ] {7c332105-7681-4b9c-a3fe-02d9fc09fca4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column SearchPhrase): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_1_10_1/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 131 with max_rows_to_read = 26936): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58520) (comment: 00033_aggregate_key_string.sql) (in query: SELECT SearchPhrase AS k1, count() AS c FROM test.hits GROUP BY k1 ORDER BY c DESC, k1 LIMIT 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ec4c9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c819454 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c814395 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c8139cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c814b7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:42.659715 [ 15589 ] {7c332105-7681-4b9c-a3fe-02d9fc09fca4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column SearchPhrase): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_1_10_1/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 131 with max_rows_to_read = 26936): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ec4c9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c819454 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c814395 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c8139cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c814b7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:42.913543 [ 3235 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:43.076055 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.226808 [ 8268 ] {2c6a2e18-1898-45b9-865f-5ee71eb8ae77} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58658) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.TestTbl update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.242885 [ 8268 ] {2c6a2e18-1898-45b9-865f-5ee71eb8ae77} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.357734 [ 3250 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:43.403990 [ 17481 ] {e6444a49-59f8-4396-8175-0c5a26041836} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'Goals.ID' in scope SELECT CounterID FROM test.visits ARRAY JOIN Goals.ID WHERE CounterID = 942285 ORDER BY CounterID ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58684) (comment: 00059_merge_sorting_empty_array_joined.sql) (in query: SELECT CounterID FROM test.visits ARRAY JOIN Goals.ID WHERE CounterID = 942285 ORDER BY CounterID ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4881: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c44fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4ed9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.422231 [ 17481 ] {e6444a49-59f8-4396-8175-0c5a26041836} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'Goals.ID' in scope SELECT CounterID FROM test.visits ARRAY JOIN Goals.ID WHERE CounterID = 942285 ORDER BY CounterID ASC. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4881: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c44fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4ed9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.465441 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:43.526905 [ 8268 ] {1b3f4b1b-04e5-4970-8e69-174a87dd2150} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cf1e91d0-ab82-42d0-b95f-7762d42a4c4a', current host ID: '793cd66ee8bf:9000:09c08c90-ea74-44f6-bde1-0a9b26c65c2a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58710) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_6 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.543027 [ 8268 ] {1b3f4b1b-04e5-4970-8e69-174a87dd2150} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cf1e91d0-ab82-42d0-b95f-7762d42a4c4a', current host ID: '793cd66ee8bf:9000:09c08c90-ea74-44f6-bde1-0a9b26c65c2a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.604942 [ 3677 ] {4a5355e9-f8b4-4933-b687-d5e4796d0c62} executeQuery: Code: 47. DB::Exception: Missing columns: 'EventDate' while processing query: 'toYYYYMM(EventDate)', required columns: 'EventDate' 'EventDate'. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58688) (comment: 00061_storage_buffer.sql) (in query: CREATE TABLE test.hits_dst AS test.hits ENGINE = MergeTree PARTITION BY toYYYYMM(EventDate) ORDER BY (CounterID, EventDate, intHash32(UserID)) SAMPLE BY intHash32(UserID) SETTINGS storage_policy = 'default', index_granularity = 44753, min_bytes_for_wide_part = 833161065, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = false, max_file_name_length = 98, min_bytes_for_full_part_storage = 215051447, compact_parts_max_bytes_to_buffer = 14556324, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 1328602, merge_max_block_size = 8836, old_parts_lifetime = 315., 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 = 9812342, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 78416, primary_key_compress_block_size = 11305), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./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 @ 0x00000000299bf5ea 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000002b6acdb1 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000002b6ae661 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:644: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb443e 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.637378 [ 3677 ] {4a5355e9-f8b4-4933-b687-d5e4796d0c62} TCPHandler: Code: 47. DB::Exception: Missing columns: 'EventDate' while processing query: 'toYYYYMM(EventDate)', required columns: 'EventDate' 'EventDate'. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./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 @ 0x00000000299bf5ea 5. ./build_docker/./src/Storages/KeyDescription.cpp:140: DB::KeyDescription::getSortingKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr, std::optional const&) @ 0x000000002b6acdb1 6. ./contrib/llvm-project/libcxx/include/optional:260: DB::KeyDescription::getKeyFromAST(std::shared_ptr const&, DB::ColumnsDescription const&, std::shared_ptr) @ 0x000000002b6ae661 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:644: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb443e 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.763704 [ 18099 ] {c058467c-e348-4a42-a68b-4224c91feee5} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58730) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.786963 [ 18099 ] {c058467c-e348-4a42-a68b-4224c91feee5} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:43.799932 [ 3377 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {855a1c57-459a-4184-97ab-17bc8cfce245::202510_1_116_23}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:43.834115 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:43.915647 [ 3274 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:44.212533 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.228460 [ 4049 ] {2307b758-9dac-4e45-8030-e60899ffff79} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38400) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.237695 [ 4049 ] {2307b758-9dac-4e45-8030-e60899ffff79} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.362792 [ 2791 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:44.468818 [ 2778 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:44.486374 [ 8268 ] {bd8e3293-adda-43a6-83f7-540c7a556eea} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT domain(URL) AS k, uniq(UserID) AS u, uniqState(UserID) AS us FROM test.hits GROUP BY k. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38390) (comment: 00038_uniq_state_merge2.sql) (in query: SELECT topLevelDomain(concat('http://', k)) AS tld, sum(u) AS u, uniqMerge(us) AS us FROM (SELECT domain(URL) AS k, uniq(UserID) AS u, uniqState(UserID) AS us FROM test.hits GROUP BY k) GROUP BY tld ORDER BY u DESC, tld ASC LIMIT 100 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.517538 [ 8268 ] {bd8e3293-adda-43a6-83f7-540c7a556eea} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT domain(URL) AS k, uniq(UserID) AS u, uniqState(UserID) AS us FROM test.hits GROUP BY k. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.568432 [ 17479 ] {c63aa9d9-62ef-48ea-b3f2-f488115ef4b9} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'Goals' in scope SELECT goals_alias.ID AS `ym:s:goalDimension`, uniqIf(UserID, (UserID != 0) AND (_uniq_Goals = 1)) FROM test.visits ARRAY JOIN Goals AS goals_alias, arrayEnumerateUniq(Goals.ID) AS _uniq_Goals WHERE CounterID = 842440 GROUP BY `ym:s:goalDimension` WITH TOTALS ORDER BY `ym:s:goalDimension` ASC LIMIT 0, 1. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38446) (comment: 00023_totals_limit.sql) (in query: SELECT goals_alias.ID AS `ym:s:goalDimension`, uniqIf(UserID, (UserID != 0) AND (`_uniq_Goals` = 1)) FROM test.visits ARRAY JOIN Goals AS goals_alias, arrayEnumerateUniq(Goals.ID) AS `_uniq_Goals` WHERE (CounterID = 842440) GROUP BY `ym:s:goalDimension` WITH TOTALS ORDER BY `ym:s:goalDimension` LIMIT 0, 1 FORMAT JSONCompact;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4881: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c44fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4ed9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.599454 [ 17479 ] {c63aa9d9-62ef-48ea-b3f2-f488115ef4b9} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'Goals' in scope SELECT goals_alias.ID AS `ym:s:goalDimension`, uniqIf(UserID, (UserID != 0) AND (_uniq_Goals = 1)) FROM test.visits ARRAY JOIN Goals AS goals_alias, arrayEnumerateUniq(Goals.ID) AS _uniq_Goals WHERE CounterID = 842440 GROUP BY `ym:s:goalDimension` WITH TOTALS ORDER BY `ym:s:goalDimension` ASC LIMIT 0, 1. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4881: DB::QueryAnalyzer::resolveArrayJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c44fa 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4ed9 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.608429 [ 15589 ] {7d66a20d-bfa6-4d99-9585-4f5887a356ab} 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.10542.altinitytest (altinity build)) (from [::1]:38472) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.655179 [ 15589 ] {7d66a20d-bfa6-4d99-9585-4f5887a356ab} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:38:44.918521 [ 2804 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:44.950155 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:45.137844 [ 4049 ] {a43edc36-f79e-46bf-b02c-e711f615a94e} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38496) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.data2014 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:45.160994 [ 4049 ] {a43edc36-f79e-46bf-b02c-e711f615a94e} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:45.368179 [ 2810 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:45.473350 [ 2815 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:45.482755 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:45.920728 [ 2824 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:45.989457 [ 3677 ] {553b361b-a4b7-4d22-a313-63c62e4ab101} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:33a615d2-380c-4d41-a2bb-8d69f005abd0', current host ID: '793cd66ee8bf:9000:2ce4e570-52a1-42a6-a73d-22c7ee627f52'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38592) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_7 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.012518 [ 3677 ] {553b361b-a4b7-4d22-a313-63c62e4ab101} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:33a615d2-380c-4d41-a2bb-8d69f005abd0', current host ID: '793cd66ee8bf:9000:2ce4e570-52a1-42a6-a73d-22c7ee627f52'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.053860 [ 15589 ] {3923c1cc-a9df-4efd-9181-e811b4fe7afe} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38532) (comment: 00172_hits_joins.gen.sql) (in query: SELECT EventDate, hits, visits FROM ( SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate ) ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c8564 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4eee 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.076821 [ 15589 ] {3923c1cc-a9df-4efd-9181-e811b4fe7afe} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c8564 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4eee 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.264354 [ 18097 ] {e2eaef32-d0aa-4c28-bc4e-bf975e854da0} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38628) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.278542 [ 18097 ] {e2eaef32-d0aa-4c28-bc4e-bf975e854da0} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.371367 [ 2849 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:46.478811 [ 2855 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:46.670231 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.734412 [ 4049 ] {e3b47f46-6ce1-4e2b-badb-ab503cc9d026} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'EventTime' in scope SELECT EventTime, EventDate, CounterID, UserID, URL, Referer FROM test.hits WHERE EventDate = toDate('2014-03-18') ORDER BY EventTime ASC, EventDate ASC, CounterID ASC, UserID ASC, URL ASC, Referer ASC LIMIT 50. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38550) (comment: 00071_merge_tree_optimize_aio.sql) (in query: INSERT INTO test.hits_snippet(EventTime, EventDate, CounterID, UserID, URL, Referer) SELECT EventTime, EventDate, CounterID, UserID, URL, Referer FROM test.hits WHERE EventDate = toDate('2014-03-18') ORDER BY EventTime, EventDate, CounterID, UserID, URL, Referer ASC LIMIT 50;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002936313a 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.770917 [ 4049 ] {e3b47f46-6ce1-4e2b-badb-ab503cc9d026} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'EventTime' in scope SELECT EventTime, EventDate, CounterID, UserID, URL, Referer FROM test.hits WHERE EventDate = toDate('2014-03-18') ORDER BY EventTime ASC, EventDate ASC, CounterID ASC, UserID ASC, URL ASC, Referer ASC LIMIT 50. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: DB::InterpreterInsertQuery::buildInsertSelectPipeline(DB::ASTInsertQuery&, std::shared_ptr) @ 0x000000002936313a 14. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:789: DB::InterpreterInsertQuery::execute() @ 0x0000000029369f20 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.925302 [ 2864 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:46.932235 [ 4147 ] {0c50144d-841b-47c7-ab83-66d7f9a0549a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38662) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:46.939015 [ 4147 ] {0c50144d-841b-47c7-ab83-66d7f9a0549a} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.070483 [ 3677 ] {c9df5153-0062-4eb4-8363-abe96ed4f1bd} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38682) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactStringsEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.121495 [ 3677 ] {c9df5153-0062-4eb4-8363-abe96ed4f1bd} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.207264 [ 18097 ] {e593bdc1-e845-455e-9e20-66d4866a0cf9} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:33a615d2-380c-4d41-a2bb-8d69f005abd0', current host ID: '793cd66ee8bf:9000:6bed03dd-3527-413c-a238-02fe7fd62ede'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38720) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_1 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.219800 [ 17478 ] {dc8d3c71-44a8-48ce-82d3-a9dc666c10b8} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'PageCharset' in scope SELECT transform(SearchEngineID, [2, 3], ['ЯндекÑ', 'Google'], PageCharset) AS title, count() AS c FROM test.hits WHERE SearchEngineID != 0 GROUP BY title HAVING c > 0 ORDER BY c DESC LIMIT 10. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38710) (comment: 00143_transform_non_const_default.sql) (in query: SELECT transform(SearchEngineID, [2, 3], ['ЯндекÑ', 'Google'], PageCharset) AS title, count() AS c FROM test.hits WHERE SearchEngineID != 0 GROUP BY title HAVING c > 0 ORDER BY c DESC LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.222758 [ 17478 ] {dc8d3c71-44a8-48ce-82d3-a9dc666c10b8} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'PageCharset' in scope SELECT transform(SearchEngineID, [2, 3], ['ЯндекÑ', 'Google'], PageCharset) AS title, count() AS c FROM test.hits WHERE SearchEngineID != 0 GROUP BY title HAVING c > 0 ORDER BY c DESC LIMIT 10. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.247699 [ 18097 ] {e593bdc1-e845-455e-9e20-66d4866a0cf9} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:33a615d2-380c-4d41-a2bb-8d69f005abd0', current host ID: '793cd66ee8bf:9000:6bed03dd-3527-413c-a238-02fe7fd62ede'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.373549 [ 2876 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:47.483451 [ 2881 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:47.742487 [ 15589 ] {1570adca-19aa-4673-9b89-97269d881670} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, uniqExact(UserID), length(groupUniqArray(UserID)), arrayUniq(groupArray(UserID)) FROM test.hits WHERE CounterID = 1704509 GROUP BY EventDate ORDER BY EventDate ASC. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38752) (comment: 00073_uniq_array.sql) (in query: SELECT EventDate, uniqExact(UserID), length(groupUniqArray(UserID)), arrayUniq(groupArray(UserID)) FROM test.hits WHERE CounterID = 1704509 GROUP BY EventDate ORDER BY EventDate;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.770424 [ 15589 ] {1570adca-19aa-4673-9b89-97269d881670} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, uniqExact(UserID), length(groupUniqArray(UserID)), arrayUniq(groupArray(UserID)) FROM test.hits WHERE CounterID = 1704509 GROUP BY EventDate ORDER BY EventDate ASC. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.915134 [ 4147 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:47.934334 [ 2894 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:48.154521 [ 3677 ] {0aed03fb-07f4-438f-a747-f75c0a1bb5cc} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'StartDate' in scope SELECT any(0) FROM test.visits WHERE toInt32(toDateTime(StartDate)) > 1000000000. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38804) (comment: 00085_monotonic_evaluation_segfault.sql) (in query: SELECT any(0) FROM test.visits WHERE (toInt32(toDateTime(StartDate))) > 1000000000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:38:48.189481 [ 3677 ] {0aed03fb-07f4-438f-a747-f75c0a1bb5cc} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'StartDate' in scope SELECT any(0) FROM test.visits WHERE toInt32(toDateTime(StartDate)) > 1000000000. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:38:48.239291 [ 15589 ] {5593bf86-341c-4dc7-91dc-24be18e2bd72} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38824) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:48.270120 [ 15589 ] {5593bf86-341c-4dc7-91dc-24be18e2bd72} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:48.325788 [ 18099 ] {8af90ba0-0c9a-426c-ba0a-d8f36b72be67} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:bc4218bc-a34c-4204-974a-cc6d94163f09', current host ID: '793cd66ee8bf:9000:5aad7c46-4b12-4e0c-b49d-0e24ece7414b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38828) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_6 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:48.339680 [ 18099 ] {8af90ba0-0c9a-426c-ba0a-d8f36b72be67} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:bc4218bc-a34c-4204-974a-cc6d94163f09', current host ID: '793cd66ee8bf:9000:5aad7c46-4b12-4e0c-b49d-0e24ece7414b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:48.375943 [ 2906 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:48.485811 [ 2909 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:48.936781 [ 2925 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:48.970622 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:49.041180 [ 18099 ] {b887136c-39f4-436e-96d5-808125d33b7d} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'Title' in scope SELECT sumDistinct(sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38844) (comment: 00160_decode_xml_component.sql) (in query: SELECT sum(DISTINCT sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:38:49.059190 [ 18099 ] {b887136c-39f4-436e-96d5-808125d33b7d} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'Title' in scope SELECT sumDistinct(sipHash64(decodeXMLComponent(Title) AS decoded)) FROM test.hits WHERE Title != decoded. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:38:49.121780 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:49.378066 [ 2938 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:49.488450 [ 2941 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:49.513986 [ 3677 ] {81994356-e91b-43f4-bd6f-11a664f4e394} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=2): (while reading column ResolutionWidth): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_1_10_1/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 0 with max_rows_to_read = 98208): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38860) (comment: 00164_quantileBfloat16.sql) (in query: SELECT CounterID AS k, quantileBFloat16(0.5)(ResolutionWidth) FROM test.hits GROUP BY k ORDER BY count() DESC, CounterID LIMIT 10;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ec4c9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c819454 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c814395 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c8139cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c814b7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:49.520939 [ 3677 ] {81994356-e91b-43f4-bd6f-11a664f4e394} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=2): (while reading column ResolutionWidth): (while reading from part /var/lib/clickhouse/store/18d/18ddfc85-d826-4dfc-8276-02d6aeb0ed82/201403_1_10_1/ in table test.hits (18ddfc85-d826-4dfc-8276-02d6aeb0ed82) located on disk default of type local, from mark 0 with max_rows_to_read = 98208): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1062: DB::AsynchronousReadBufferFromFileDescriptor::prefetch(Priority) @ 0x00000000265ec4c9 11. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&, unsigned long, bool, unsigned long, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map, std::hash, std::equal_to, std::allocator>>>&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c819454 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c814395 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:109: DB::MergeTreeReaderWide::prefetchForAllColumns(Priority, unsigned long, unsigned long, unsigned long, bool) @ 0x000000002c8139cb 15. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c814b7a 16. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 17. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 20. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:38:49.683455 [ 15589 ] {61990b49-c926-4e00-adcc-153c02222b5f} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a = 301) AND (b < 20). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38906) (comment: 00636_partition_key_parts_pruning.sh) (in query: SELECT count() FROM composite_partition_key WHERE a = 301 AND b < 20 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:38:49.716945 [ 15589 ] {61990b49-c926-4e00-adcc-153c02222b5f} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a = 301) AND (b < 20). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:38:49.874081 [ 8268 ] {f461dd02-0062-44be-9f4d-6bbed5750bcd} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:33a615d2-380c-4d41-a2bb-8d69f005abd0', current host ID: '793cd66ee8bf:9000:a49327ce-319b-492c-a4ec-81cd8da662ad'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38938) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_5 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:49.926561 [ 8268 ] {f461dd02-0062-44be-9f4d-6bbed5750bcd} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:33a615d2-380c-4d41-a2bb-8d69f005abd0', current host ID: '793cd66ee8bf:9000:a49327ce-319b-492c-a4ec-81cd8da662ad'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:49.939425 [ 2953 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:50.182316 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:50.252796 [ 3677 ] {a58ca40d-9514-4893-9ede-25af073d7fd6} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'SendTiming' in scope SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38956) (comment: 00149_quantiles_timing_distributed.sql) (in query: SELECT sum(cityHash64(*)) FROM (SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:38:50.266605 [ 3677 ] {a58ca40d-9514-4893-9ede-25af073d7fd6} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'SendTiming' in scope SELECT CounterID, quantileTiming(0.5)(SendTiming), count() FROM remote('127.0.0.{1,2,3,4,5,6,7,8,9,10}', test.hits) WHERE SendTiming != -1 GROUP BY CounterID. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 16. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 19. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 20. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:38:50.454018 [ 2962 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:50.492964 [ 2971 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:50.495351 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:50.653370 [ 17478 ] {1f498709-edcb-44a0-929c-71c8eb99fd90} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (b >= 12) AND (c = 2). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38980) (comment: 00636_partition_key_parts_pruning.sh) (in query: SELECT count() FROM composite_partition_key WHERE b >= 12 AND c = 2 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:38:50.663028 [ 17478 ] {1f498709-edcb-44a0-929c-71c8eb99fd90} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (b >= 12) AND (c = 2). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:38:50.781937 [ 3677 ] {93efbd79-5051-47d5-ab99-a1125435cd22} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38990) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactStringsEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:50.808276 [ 3677 ] {93efbd79-5051-47d5-ab99-a1125435cd22} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:38:50.944412 [ 2983 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:51.134436 [ 17479 ] {09ca760a-96fc-4660-b152-51a3dde2c3ba} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cf1e91d0-ab82-42d0-b95f-7762d42a4c4a', current host ID: '793cd66ee8bf:9000:bc4c1f81-ba66-4926-97bc-9e3cc01bdc13'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39000) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_7 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.138678 [ 17479 ] {09ca760a-96fc-4660-b152-51a3dde2c3ba} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:cf1e91d0-ab82-42d0-b95f-7762d42a4c4a', current host ID: '793cd66ee8bf:9000:bc4c1f81-ba66-4926-97bc-9e3cc01bdc13'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.375354 [ 8268 ] {5e000aa0-5ab4-4b17-88b9-fef2f44d07bd} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38974) (comment: 00165_jit_aggregate_functions.sql) (in query: SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.387995 [ 8268 ] {5e000aa0-5ab4-4b17-88b9-fef2f44d07bd} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'WatchID' in scope SELECT CounterID, min(WatchID), max(WatchID), sum(WatchID), avg(WatchID), avgWeighted(WatchID, CounterID), count(WatchID), groupBitOr(WatchID), groupBitAnd(WatchID), groupBitXor(WatchID) FROM test.hits GROUP BY CounterID ORDER BY count() DESC LIMIT 20. Maybe you meant: ['WatchIDs']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.392128 [ 18099 ] {4850454e-0337-46a1-b2c6-433d2e7985eb} executeQuery: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_8: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38962) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1_repl_01111_8), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.400353 [ 18099 ] {4850454e-0337-46a1-b2c6-433d2e7985eb} TCPHandler: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_8: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.457992 [ 2996 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:51.485418 [ 3677 ] {11ff077e-5f2b-4dff-a012-4795e89ae1ff} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika')). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39018) (comment: 00089_position_functions_with_non_constant_arg.sql) (in query: SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.491356 [ 17479 ] {b6419b67-9473-4449-b823-f69b1caf345c} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a = 301) AND (b = 21) AND (c = 3). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39020) (comment: 00636_partition_key_parts_pruning.sh) (in query: SELECT count() FROM composite_partition_key WHERE a = 301 AND b = 21 AND c = 3 FORMAT XML SETTINGS optimize_trivial_count_query = 0, optimize_use_implicit_projections = 0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.497927 [ 3677 ] {11ff077e-5f2b-4dff-a012-4795e89ae1ff} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'URL' in scope SELECT count() FROM test.hits WHERE position(URL, 'metrika') != position(URL, materialize('metrika')). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.502028 [ 3001 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:51.537971 [ 17479 ] {b6419b67-9473-4449-b823-f69b1caf345c} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'composite_partition_key' in scope SELECT count() FROM composite_partition_key WHERE (a = 301) AND (b = 21) AND (c = 3). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.662866 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:51.946736 [ 3016 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:52.191528 [ 15589 ] {973b3e18-f783-4931-be85-fa445fccd013} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:37a6140f-2204-4312-a997-c741fa21a12c'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39058) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_2 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:52.211869 [ 15589 ] {973b3e18-f783-4931-be85-fa445fccd013} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:37a6140f-2204-4312-a997-c741fa21a12c'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:52.359712 [ 8268 ] {f7e7fd49-9b20-4faa-91c6-157015668fc6} executeQuery: Code: 60. DB::Exception: Table test_13.composite_partition_key does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39080) (comment: 00636_partition_key_parts_pruning.sh) (in query: DROP TABLE composite_partition_key), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c626c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd4b1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:38:52.370573 [ 8268 ] {f7e7fd49-9b20-4faa-91c6-157015668fc6} TCPHandler: Code: 60. DB::Exception: Table test_13.composite_partition_key does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:971: DB::DatabaseCatalog::getDatabaseAndTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c626c 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd4b1 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:38:52.461183 [ 3014 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:52.505099 [ 3035 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:52.955777 [ 3040 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:52.989801 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:53.464664 [ 3051 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:53.508554 [ 3057 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:53.959334 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:54.105685 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:54.304694 [ 18097 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:54.448412 [ 16283 ] {6917c166-7f37-4c29-96a3-89a669bf8efe} executeQuery: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_8: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39156) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1_repl_01111_8), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:54.464313 [ 16283 ] {6917c166-7f37-4c29-96a3-89a669bf8efe} TCPHandler: Code: 159. DB::Exception: SYNC DATABASE REPLICA test_1_repl_01111_8: database is readonly or command timed out. See the 'receive_timeout' setting. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1218: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbdc5c 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:38:54.470299 [ 3090 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:54.511982 [ 3086 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:54.965663 [ 3096 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:55.451522 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:55.473515 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:55.547192 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:55.629514 [ 3105 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:55.918796 [ 18097 ] {add534fd-db0f-4bcb-8ecc-b1da31cfbda4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51592) (comment: 00159_parallel_formatting_csv_and_friends.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a, MobilePhoneModel as b, ClientIP6 as c FROM test.hits ORDER BY a, b, c Format CSV), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:38:55.938763 [ 18097 ] {add534fd-db0f-4bcb-8ecc-b1da31cfbda4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=6, jobs=6). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:38:55.971548 [ 3118 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:56.476872 [ 3132 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:56.632922 [ 3134 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:56.974292 [ 3143 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:57.040513 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:57.480742 [ 3152 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:57.635490 [ 3151 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:57.980960 [ 3160 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:58.242769 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:58.489457 [ 3174 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:58.673232 [ 3173 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:58.984065 [ 3187 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:59.224361 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:59.451889 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:38:59.517154 [ 3392 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f031c251-ff48-4808-844a-5edfe9b82eeb::202510_1_117_87}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:59.521212 [ 3199 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:59.612616 [ 3677 ] {65660f5f-60b1-48c6-93a3-0bc68018018f} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:39088) (comment: 00056_view.sql) (in query: DROP TABLE test.view;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:59.621252 [ 3677 ] {65660f5f-60b1-48c6-93a3-0bc68018018f} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:38:59.675827 [ 3208 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:38:59.986875 [ 3210 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:00.527242 [ 3222 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:00.590231 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:00.678660 [ 3226 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:00.711284 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:00.990631 [ 3234 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:01.534109 [ 3249 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:01.680987 [ 3254 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:01.993404 [ 3247 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:02.345353 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:02.632341 [ 3272 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:02.683277 [ 3271 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:03.003166 [ 3275 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:03.623772 [ 18917 ] {2814a085-caa2-4b5a-904c-df19158f3e7e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51790) (comment: 00159_parallel_formatting_json_and_friends_2.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a, MobilePhoneModel as b, ClientIP6 as c FROM test.hits ORDER BY a, b, c LIMIT 3000000 Format JSONCompactStringsEachRowWithNames), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:39:03.635256 [ 3280 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:03.639710 [ 18917 ] {2814a085-caa2-4b5a-904c-df19158f3e7e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:39:03.685931 [ 3276 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:04.005668 [ 2788 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:04.412708 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:04.685162 [ 2799 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:04.706839 [ 2777 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:04.920078 [ 19038 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:05.013297 [ 2808 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:05.725116 [ 2826 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:05.725140 [ 2827 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:05.994341 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:06.030314 [ 2825 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:06.146987 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:06.744134 [ 2851 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:06.744719 [ 2855 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:07.036524 [ 2865 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:07.504840 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:07.759861 [ 2872 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:07.763488 [ 2875 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:08.047223 [ 2885 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:08.701378 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:08.762984 [ 2903 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:08.766838 [ 2901 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:09.054795 [ 2906 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:09.719277 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:09.780352 [ 2926 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:09.779974 [ 2924 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:09.950347 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:10.058805 [ 2921 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:10.783861 [ 2942 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:10.784528 [ 2932 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:11.063372 [ 2952 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:11.155038 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:11.190735 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:11.788617 [ 2966 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:11.794339 [ 2971 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:12.066200 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:12.451897 [ 17478 ] {af8724ce-40e3-4f72-b864-dc18b2d9edb8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column n): (while reading from part /var/lib/clickhouse/store/41d/41df4b43-240f-45ef-a11e-eb4a0f28ec57/all_4_4_0/ in table test_13.huge_strings (41df4b43-240f-45ef-a11e-eb4a0f28ec57) located on disk default of type local, from mark 0 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38032) (comment: 01184_long_insert_values_huge_strings.sh) (in query: select sum(l = length(s)) from huge_strings), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CachedCompressedReadBuffer::nextImpl() @ 0x000000002c80d03d 14. DB::ReadBuffer::next() @ 0x000000000b52caeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027c15812 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dec1114 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 2025.10.23 23:39:12.472771 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:12.498438 [ 17478 ] {af8724ce-40e3-4f72-b864-dc18b2d9edb8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column n): (while reading from part /var/lib/clickhouse/store/41d/41df4b43-240f-45ef-a11e-eb4a0f28ec57/all_4_4_0/ in table test_13.huge_strings (41df4b43-240f-45ef-a11e-eb4a0f28ec57) located on disk default of type local, from mark 0 with max_rows_to_read = 57344): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CachedCompressedReadBuffer::nextImpl() @ 0x000000002c80d03d 14. DB::ReadBuffer::next() @ 0x000000000b52caeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027c15812 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dec1114 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 2025.10.23 23:39:12.801392 [ 2988 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:12.810853 [ 2984 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:13.070548 [ 2993 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:13.676476 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:13.805387 [ 3003 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:13.813359 [ 3004 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:14.073245 [ 3012 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:14.172714 [ 16283 ] {0964b9e6-aad9-407f-abdc-7fd1bad8d26b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column s): (while reading from part /var/lib/clickhouse/store/41d/41df4b43-240f-45ef-a11e-eb4a0f28ec57/all_1_6_1/ in table test_13.huge_strings (41df4b43-240f-45ef-a11e-eb4a0f28ec57) located on disk default of type local, from mark 17 with max_rows_to_read = 31018): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38066) (comment: 01184_long_insert_values_huge_strings.sh) (in query: select sum(h = cityHash64(s)) from huge_strings), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CachedCompressedReadBuffer::nextImpl() @ 0x000000002c80d03d 14. DB::ReadBuffer::next() @ 0x000000000b52caeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027c15812 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 2025.10.23 23:39:14.178703 [ 16283 ] {0964b9e6-aad9-407f-abdc-7fd1bad8d26b} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column s): (while reading from part /var/lib/clickhouse/store/41d/41df4b43-240f-45ef-a11e-eb4a0f28ec57/all_1_6_1/ in table test_13.huge_strings (41df4b43-240f-45ef-a11e-eb4a0f28ec57) located on disk default of type local, from mark 17 with max_rows_to_read = 31018): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769abb 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CachedCompressedReadBuffer::nextImpl() @ 0x000000002c80d03d 14. DB::ReadBuffer::next() @ 0x000000000b52caeb 15. ./build_docker/./src/DataTypes/Serializations/SerializationSparse.cpp:85: DB::SerializationSparse::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027c15812 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 2025.10.23 23:39:14.812693 [ 3034 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:14.819473 [ 3035 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:14.868008 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:14.886759 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:15.080840 [ 3040 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:15.816566 [ 3056 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:15.824658 [ 3050 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:16.083909 [ 3061 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:16.086695 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:16.275905 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:16.827526 [ 3071 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:16.916139 [ 3076 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:16.973697 [ 16283 ] {95a0635e-1f82-42bf-bf22-2d7da68ebfd5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=756). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45214) (comment: 01355_defaultValueOfArgumentType_bug.sql) (in query: SELECT materialize(toLowCardinality('')) AS lc, toTypeName(lc) WHERE lc = defaultValueOfArgumentType(lc) ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:16.992896 [ 16283 ] {95a0635e-1f82-42bf-bf22-2d7da68ebfd5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=756). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:17.091793 [ 3083 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:17.377940 [ 16283 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:17.837196 [ 3091 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:17.919837 [ 3093 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:18.094774 [ 3097 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:18.628008 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:18.840765 [ 3106 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:18.931449 [ 3114 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:19.097596 [ 3127 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:19.835802 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:19.843917 [ 3128 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:19.936358 [ 3133 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:20.051185 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:20.100477 [ 3139 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:20.284423 [ 3677 ] {951e45aa-155f-4373-9d04-be5067485868} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45268) (comment: 00159_parallel_formatting_json_and_friends_2.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a, MobilePhoneModel as b, ClientIP6 as c FROM test.hits ORDER BY a, b, c LIMIT 3000000 Format JSONCompactStringsEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:39:20.298569 [ 3677 ] {951e45aa-155f-4373-9d04-be5067485868} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:39:20.846940 [ 3152 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:21.009455 [ 3148 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:21.103349 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:21.110538 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:21.399755 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:21.463177 [ 18099 ] {db57c3ac-1cc7-4df7-8be2-6059df2e129e} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45280) (comment: 00159_parallel_formatting_json_and_friends_2.sh) (in query: SELECT ClientEventTime::DateTime('Asia/Dubai') as a, MobilePhoneModel as b, ClientIP6 as c FROM test.hits ORDER BY a, b, c LIMIT 3000000 Format JSONCompactStringsEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:39:21.471483 [ 18099 ] {db57c3ac-1cc7-4df7-8be2-6059df2e129e} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=1): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:39:21.850329 [ 3172 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:22.016068 [ 3180 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:22.135623 [ 3173 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:22.489188 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:22.853731 [ 3194 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:23.024125 [ 3202 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:23.138816 [ 3196 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:23.681419 [ 17478 ] {b85f89ef-b15f-4544-801f-b69b09847332} 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.10542.altinitytest (altinity build)) (from [::1]:45314) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: CREATE TABLE hits_s3_sampled AS test.hits_s3), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c470388 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbc2fc8 9. ./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>&&) @ 0x000000002cbc1b9a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb8258 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:23.692917 [ 17478 ] {b85f89ef-b15f-4544-801f-b69b09847332} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c470388 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbc2fc8 9. ./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>&&) @ 0x000000002cbc1b9a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb8258 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:23.737468 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:23.856664 [ 3213 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:24.034452 [ 3221 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:24.086033 [ 17478 ] {9d909566-0b44-4670-a0ce-35705a70b29b} executeQuery: Code: 60. DB::Exception: Table test_9.hits_s3_sampled does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45334) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: INSERT INTO hits_s3_sampled SELECT * FROM test.hits_s3 SAMPLE 0.01), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:24.099627 [ 17478 ] {9d909566-0b44-4670-a0ce-35705a70b29b} TCPHandler: Code: 60. DB::Exception: Table test_9.hits_s3_sampled does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:24.142439 [ 3226 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:24.529494 [ 17478 ] {a6e143b3-c705-46a4-a727-08cbfc9c7471} executeQuery: Code: 60. DB::Exception: Table test_9.hits_s3_sampled does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42412) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: OPTIMIZE TABLE hits_s3_sampled FINAL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be8322 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:39:24.551304 [ 17478 ] {a6e143b3-c705-46a4-a727-08cbfc9c7471} TCPHandler: Code: 60. DB::Exception: Table test_9.hits_s3_sampled does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:0: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be8322 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:39:24.865024 [ 3237 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:25.017615 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:25.037329 [ 3248 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:25.145937 [ 3241 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:25.265849 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:25.868651 [ 3261 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:26.050325 [ 3262 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:26.149080 [ 3263 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:26.326843 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:26.494548 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:26.617803 [ 3677 ] {17768b9d-9dd0-48a3-acd6-1b0102cb16f2} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42474) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format TSVWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:26.626899 [ 3677 ] {17768b9d-9dd0-48a3-acd6-1b0102cb16f2} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:26.873564 [ 3273 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:27.053694 [ 2774 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:27.152711 [ 3279 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:27.477114 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:27.877204 [ 2801 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:28.057108 [ 2800 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:28.156458 [ 2790 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:28.780347 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:28.880532 [ 2812 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:29.061137 [ 2817 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:29.159273 [ 2811 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:29.883101 [ 2824 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:29.987334 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:30.066229 [ 2820 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:30.162130 [ 2834 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:30.264113 [ 18099 ] {d4e63b69-047d-4ccb-b6fa-e91cb3e29afc} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000005 */ CREATE TABLE test_5.parsing_with_names UUID '8486ef42-678a-4898-988c-538d72daaaab' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:30.323274 [ 18099 ] {d4e63b69-047d-4ccb-b6fa-e91cb3e29afc} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42526) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:30.335020 [ 18099 ] {d4e63b69-047d-4ccb-b6fa-e91cb3e29afc} TCPHandler: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:30.501923 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:30.886414 [ 2852 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:31.069281 [ 2857 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:31.164881 [ 2854 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:31.261320 [ 3677 ] {f4ed08c5-95e3-4d81-9350-62c9743ebffb} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42544) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format TSVWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:31.268762 [ 18908 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:31.273217 [ 3677 ] {f4ed08c5-95e3-4d81-9350-62c9743ebffb} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:31.631165 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:31.889324 [ 2873 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:32.071907 [ 2874 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:32.167830 [ 2876 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:32.546787 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:32.896929 [ 2887 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.074347 [ 2891 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.171554 [ 2892 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:33.810472 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:33.900084 [ 2900 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:34.076804 [ 2906 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:34.174182 [ 2909 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:34.311577 [ 17479 ] {3089f956-4788-4a04-b665-094b475024cd} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000007 */ CREATE TABLE test_5.parsing_with_names UUID 'a9a9191b-ab78-4a6d-b765-e59de6a485a4' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:34.373151 [ 17479 ] {3089f956-4788-4a04-b665-094b475024cd} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45320) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:34.379248 [ 17479 ] {3089f956-4788-4a04-b665-094b475024cd} TCPHandler: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:34.902956 [ 2934 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:35.079411 [ 2939 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:35.110198 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:35.176939 [ 2943 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:35.376132 [ 17479 ] {2d13be7b-4901-435c-834d-804de340f2ed} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45346) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format CSVWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:35.381679 [ 17479 ] {2d13be7b-4901-435c-834d-804de340f2ed} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:35.770319 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:35.979553 [ 2952 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:36.081751 [ 2949 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:36.180598 [ 2955 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:36.382857 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:36.838009 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:36.982661 [ 2975 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:37.085091 [ 2979 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:37.183792 [ 2982 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:37.520992 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:37.985491 [ 3003 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:38.088128 [ 3005 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:38.238870 [ 3010 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:38.269220 [ 3677 ] {45a9e925-267d-4f58-a115-c56ca700f086} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000009 */ CREATE TABLE test_5.parsing_with_names UUID '37b72906-c1af-4afc-b273-93df2fb1294e' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:38.299853 [ 3677 ] {45a9e925-267d-4f58-a115-c56ca700f086} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45406) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:38.327454 [ 3677 ] {45a9e925-267d-4f58-a115-c56ca700f086} TCPHandler: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:38.754749 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:38.988801 [ 3030 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:39.052781 [ 3677 ] {ee0520a9-42e7-44aa-916e-602d527a01d0} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45422) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format CSVWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:39.061640 [ 3677 ] {ee0520a9-42e7-44aa-916e-602d527a01d0} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:39.090424 [ 3037 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:39.246542 [ 3039 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:39.991531 [ 3072 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:40.048675 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:40.093166 [ 3069 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:40.249958 [ 3077 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:40.732347 [ 18917 ] {ec336ecc-283e-4484-9ce1-a7f6299520fd} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'hits_s3_sampled' in scope SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime ASC LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45468) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime LIMIT 10 FORMAT Null SETTINGS filesystem_cache_reserve_space_wait_lock_timeout_milliseconds=2000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:39:40.759495 [ 18917 ] {ec336ecc-283e-4484-9ce1-a7f6299520fd} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'hits_s3_sampled' in scope SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime ASC LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:39:40.944455 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:40.995009 [ 3084 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:41.096116 [ 3089 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:41.243588 [ 18926 ] {3ec1ff83-9d58-41db-92ca-8619c1f2146a} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'hits_s3_sampled' in scope SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime ASC LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45486) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime LIMIT 10 FORMAT Null SETTINGS filesystem_cache_reserve_space_wait_lock_timeout_milliseconds=2000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:39:41.255299 [ 18926 ] {3ec1ff83-9d58-41db-92ca-8619c1f2146a} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'hits_s3_sampled' in scope SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime ASC LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:39:41.255502 [ 3094 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:41.376080 [ 18928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:41.726553 [ 18917 ] {02906_read_from_cache_21762} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'hits_s3_sampled' in scope SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime ASC LIMIT 10. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45508) (comment: 00180_no_seek_avoiding_when_reading_from_cache.sh) (in query: SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime LIMIT 10 FORMAT Null SETTINGS filesystem_cache_reserve_space_wait_lock_timeout_milliseconds=2000), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:39:41.741828 [ 18917 ] {02906_read_from_cache_21762} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'hits_s3_sampled' in scope SELECT * FROM hits_s3_sampled WHERE URL LIKE '%google%' ORDER BY EventTime ASC LIMIT 10. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:39:41.998339 [ 3113 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:42.098975 [ 3112 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:42.100201 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:42.265071 [ 3117 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:42.415825 [ 18926 ] {03302a29-3e35-4e59-ac0a-ab85c54036a4} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000011 */ CREATE TABLE test_5.parsing_with_names UUID '15f6d2bb-95d9-4796-83dc-7f0beb13c5f9' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:42.431512 [ 3388 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {1c1299da-d909-4b7c-85cc-168a8083c3c9::202510_1_110_22}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:42.456989 [ 18926 ] {03302a29-3e35-4e59-ac0a-ab85c54036a4} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45544) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:42.476898 [ 18926 ] {03302a29-3e35-4e59-ac0a-ab85c54036a4} TCPHandler: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:42.597182 [ 18917 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.004838 [ 3143 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:43.074544 [ 18965 ] {23b6dbbb-2b22-4671-86cd-1e95810d8538} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45662) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.094919 [ 18965 ] {23b6dbbb-2b22-4671-86cd-1e95810d8538} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.101010 [ 3144 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:43.111777 [ 18958 ] {09d8faa0-f003-4f31-a844-82ab6d79c156} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45636) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.114183 [ 18958 ] {09d8faa0-f003-4f31-a844-82ab6d79c156} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.267246 [ 3150 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:43.384988 [ 18928 ] {a4b40697-c35a-45c2-a6ac-f6060c10f060} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45670) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONStringsEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.396938 [ 18928 ] {a4b40697-c35a-45c2-a6ac-f6060c10f060} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.768539 [ 18917 ] {829b2dc3-ff42-42d2-aad8-fa3f8f3845c6} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45692) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.783392 [ 18917 ] {829b2dc3-ff42-42d2-aad8-fa3f8f3845c6} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.802516 [ 18954 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.840844 [ 18928 ] {bf5205a6-692e-4fc5-9d58-f269914a005f} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45710) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.867789 [ 18928 ] {bf5205a6-692e-4fc5-9d58-f269914a005f} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.891017 [ 18933 ] {c0106146-cd0e-457e-9c1e-0f3df9dbce1c} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45722) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:43.930408 [ 18933 ] {c0106146-cd0e-457e-9c1e-0f3df9dbce1c} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:44.043612 [ 3210 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:44.103259 [ 3214 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:44.269489 [ 3217 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:44.873255 [ 18965 ] {70874d0b-8c31-460f-8a29-9dbc7dd58195} executeQuery: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51104) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:44.886758 [ 18965 ] {70874d0b-8c31-460f-8a29-9dbc7dd58195} TCPHandler: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:44.956656 [ 19026 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:45.023464 [ 19006 ] {9c7dc885-2f3b-4978-95c2-672887913bf9} executeQuery: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51146) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:45.051405 [ 3262 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:45.050485 [ 19006 ] {9c7dc885-2f3b-4978-95c2-672887913bf9} TCPHandler: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:45.104941 [ 3258 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:45.272663 [ 3277 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:45.894722 [ 18958 ] {e7607f9d-43a2-4c58-ab9a-f2309740730f} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51234) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:45.912917 [ 18958 ] {e7607f9d-43a2-4c58-ab9a-f2309740730f} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value1` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:46.063551 [ 2804 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:46.111143 [ 2789 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:46.131917 [ 18958 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:46.189227 [ 18965 ] {3a566274-4c12-4894-ae46-58d9540abb09} executeQuery: Code: 36. DB::Exception: Cannot drop column value5 because it's affected by mutation with ID '0000000000' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000000'". (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51250) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000002c541a9a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000002c4b058d 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb5b053 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:39:46.207578 [ 18965 ] {3a566274-4c12-4894-ae46-58d9540abb09} TCPHandler: Code: 36. DB::Exception: Cannot drop column value5 because it's affected by mutation with ID '0000000000' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000000'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000002c541a9a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000002c4b058d 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb5b053 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:39:46.275703 [ 2808 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:46.473843 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:46.974124 [ 18958 ] {222b807d-accb-4f55-ba1e-9d469e16c389} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000013 */ CREATE TABLE test_5.parsing_with_names UUID '1e23a3ba-1ad2-42b0-a284-54e56b11f184' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.027989 [ 18958 ] {222b807d-accb-4f55-ba1e-9d469e16c389} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51296) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.031228 [ 18958 ] {222b807d-accb-4f55-ba1e-9d469e16c389} TCPHandler: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.065503 [ 2830 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:47.114187 [ 2837 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:47.277996 [ 2843 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:47.328571 [ 19026 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.345617 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:47.528205 [ 18933 ] {9535c6cb-717a-4c97-9805-b4dd46e78a9c} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51376) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.538842 [ 18933 ] {9535c6cb-717a-4c97-9805-b4dd46e78a9c} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.540679 [ 19006 ] {e9968f22-fd5c-4364-b285-de4a35dbf565} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51360) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.543258 [ 19006 ] {e9968f22-fd5c-4364-b285-de4a35dbf565} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.882380 [ 18965 ] {787c618f-9bef-45fd-bb43-1d16023e9b0f} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51416) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONStringsEachRow), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.895878 [ 18965 ] {787c618f-9bef-45fd-bb43-1d16023e9b0f} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.971832 [ 18958 ] {7d3ee358-4a06-4b8c-9774-75c2c0880a0f} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51444) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:47.994037 [ 18958 ] {7d3ee358-4a06-4b8c-9774-75c2c0880a0f} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:48.067853 [ 2871 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:48.117651 [ 2878 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:48.189617 [ 18958 ] {8fe61b1c-0765-423f-8e47-8fa85eb3c7c6} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51458) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:48.214420 [ 18958 ] {8fe61b1c-0765-423f-8e47-8fa85eb3c7c6} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:48.280158 [ 2890 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:48.496294 [ 18933 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.074300 [ 2931 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:49.117827 [ 4147 ] {5f99fc7d-5060-4d8e-8e60-b979bd438e8f} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38854) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.122806 [ 2924 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:49.136480 [ 4147 ] {5f99fc7d-5060-4d8e-8e60-b979bd438e8f} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.174349 [ 18933 ] {68098fcf-2934-434e-bf9e-d2c574110497} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51546) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.183600 [ 18933 ] {68098fcf-2934-434e-bf9e-d2c574110497} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.282492 [ 2933 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:49.341066 [ 18958 ] {d3974d95-7a5d-416e-af5c-9f6851bc68f8} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51530) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.355689 [ 18965 ] {ab6cd36d-1a45-4566-b2dd-1cfaca6e6d36} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51468) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.393950 [ 18958 ] {d3974d95-7a5d-416e-af5c-9f6851bc68f8} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.420309 [ 18965 ] {ab6cd36d-1a45-4566-b2dd-1cfaca6e6d36} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:49.691762 [ 18965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:50.030730 [ 18933 ] {1b02587e-5ea4-4f95-8fa0-2d6c361716a9} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51612) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:50.039331 [ 18933 ] {1b02587e-5ea4-4f95-8fa0-2d6c361716a9} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:50.078441 [ 2958 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:50.106428 [ 18999 ] {fdcbd9b9-d45d-4981-8e44-2efbbf5813fb} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51630) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:50.135585 [ 18999 ] {fdcbd9b9-d45d-4981-8e44-2efbbf5813fb} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value2` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:50.140259 [ 2966 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:50.290868 [ 2971 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:50.866464 [ 18999 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:50.963169 [ 19006 ] {1baec82d-8d17-43ca-927b-2b4c1574469a} executeQuery: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51694) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value4 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:50.967286 [ 19006 ] {1baec82d-8d17-43ca-927b-2b4c1574469a} TCPHandler: Code: 15. DB::Exception: Cannot add column `value4`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:51.080545 [ 3027 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:51.102945 [ 18965 ] {d8f107f8-cc54-48c4-ba39-a24c816ff8d9} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000015 */ CREATE TABLE test_5.parsing_with_names UUID '07e4e0e2-8a35-4bdb-928c-61672c0868af' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:51.146454 [ 3026 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:51.217103 [ 18965 ] {d8f107f8-cc54-48c4-ba39-a24c816ff8d9} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51664) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:51.220375 [ 18965 ] {d8f107f8-cc54-48c4-ba39-a24c816ff8d9} TCPHandler: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:51.293168 [ 3037 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:51.908014 [ 19006 ] {98de8a9f-791c-4b46-a00e-fffa806ffbbe} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51736) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value2 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:51.912568 [ 19006 ] {98de8a9f-791c-4b46-a00e-fffa806ffbbe} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:51.943531 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.055065 [ 19026 ] {cc6c5baf-fdc2-4e68-97c7-0ed32fc96bbf} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51792) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:52.067891 [ 18965 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:52.082768 [ 3063 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.085721 [ 19026 ] {cc6c5baf-fdc2-4e68-97c7-0ed32fc96bbf} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:52.149303 [ 3071 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.168035 [ 19023 ] {908c6e7d-e78d-4ba8-ac25-a76bf8aba853} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51776) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:52.174874 [ 19023 ] {908c6e7d-e78d-4ba8-ac25-a76bf8aba853} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value5` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:52.282895 [ 17627 ] {4dfb44dc-74d7-4bd1-a6ed-5dbd247ccbb6} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44096) (comment: 03171_function_to_subcolumns_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_qtmmr1n4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:39:52.285520 [ 17627 ] {4dfb44dc-74d7-4bd1-a6ed-5dbd247ccbb6} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.298549 [ 3378 ] {6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac::all_0_5_4_6} 6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac::all_0_5_4_6 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_5_4_6 from 3 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (7d05f7c33141ac772ce426af640291c9) data.bin: 411127 (d2d22d5016ee22f4feae29608fbbf41b) data.cmrk3: 298 (3494e8c54a83f46c7d9b5674682a2b33) primary.cidx: 90 (12ea71407e33aa8073b10f6b3b0c4f9b) serialization.json: 456 (a0403d89effb343a04e07e271ddb9ee9) 2025.10.23 23:39:52.299615 [ 3087 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.721482 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:52.821312 [ 19038 ] {0e80b922-f402-4bec-8b30-fbc463cd0e63} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51872) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:52.830809 [ 19038 ] {0e80b922-f402-4bec-8b30-fbc463cd0e63} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:53.105531 [ 3119 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:53.152046 [ 3123 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:53.174998 [ 18982 ] {b33f1ed8-56af-45b7-8778-3299eb12a297} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51074) (comment: 00173_group_by_use_nulls.sql) (in query: SELECT CounterID AS k, quantileBFloat16(0.5)(ResolutionWidth) FROM test.hits GROUP BY k ORDER BY count() DESC, CounterID ASC LIMIT 10 SETTINGS group_by_use_nulls = 1 FORMAT Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:39:53.180389 [ 18097 ] {0c095ca6-9cb1-42b4-a4d5-f7dd5b2ca740} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51896) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:53.182067 [ 18982 ] {b33f1ed8-56af-45b7-8778-3299eb12a297} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=1): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000027aa8df5 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPoolInOrder.cpp:74: DB::MergeTreeReadPoolInOrder::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df1b431 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectAlgorithms.cpp:17: DB::MergeTreeInOrderSelectAlgorithm::getNewTask(DB::IMergeTreeReadPool&, DB::MergeTreeReadTask*) @ 0x000000002debf6b9 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 22. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 23. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 24. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 26. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 27. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 28. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:39:53.182868 [ 18097 ] {0c095ca6-9cb1-42b4-a4d5-f7dd5b2ca740} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:53.202229 [ 18910 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:53.307763 [ 3144 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:54.092783 [ 18097 ] {2ff33d75-3823-42c4-b33d-a4727a9ef448} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51938) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:54.103668 [ 18097 ] {2ff33d75-3823-42c4-b33d-a4727a9ef448} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:54.107873 [ 3187 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:54.154454 [ 3173 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:54.311270 [ 3192 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:54.498727 [ 19006 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:54.759186 [ 16283 ] {4e98b830-7db2-414d-aecc-8bf6b1a85dd9} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:51978) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:54.764850 [ 16283 ] {4e98b830-7db2-414d-aecc-8bf6b1a85dd9} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:55.117580 [ 3220 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:55.156782 [ 3219 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:55.178383 [ 18097 ] {7366be9e-3cfc-4d1b-8590-abe08be06539} executeQuery: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47758) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:55.242725 [ 18097 ] {7366be9e-3cfc-4d1b-8590-abe08be06539} TCPHandler: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:55.313461 [ 3233 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:55.596719 [ 3677 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:55.614925 [ 18097 ] {fa127fe0-6a68-4974-8c5c-59b6e010838d} executeQuery: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47784) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:55.674841 [ 18097 ] {fa127fe0-6a68-4974-8c5c-59b6e010838d} TCPHandler: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:55.913179 [ 18097 ] {2e1eae23-8fa5-4a4e-8719-3a43baa73cb2} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47860) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:55.943246 [ 18097 ] {2e1eae23-8fa5-4a4e-8719-3a43baa73cb2} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:56.008291 [ 3385 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {925e7f92-761d-4ac7-89dc-ee5b4ebf568e::202510_1_75_15}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:56.120035 [ 3272 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:56.159007 [ 3256 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:56.315930 [ 3269 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:56.547478 [ 18910 ] {f2532494-dc8c-46f6-80e0-f1d2e578bb65} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47898) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 DROP COLUMN value4 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:56.587216 [ 18910 ] {f2532494-dc8c-46f6-80e0-f1d2e578bb65} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `value4` to drop. Maybe you meant: ['value0']. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:39:56.715567 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:56.767115 [ 18097 ] {b6825527-396c-4310-ac1e-ae5db2bc0bf9} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47886) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value1 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:56.778581 [ 18097 ] {b6825527-396c-4310-ac1e-ae5db2bc0bf9} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:56.953615 [ 17479 ] {3c0ab78c-ae2c-462a-8b23-7652b2287cbd} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47948) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:56.966740 [ 17479 ] {3c0ab78c-ae2c-462a-8b23-7652b2287cbd} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:39:57.126758 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:57.126896 [ 2795 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:57.160868 [ 2805 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:57.321944 [ 2776 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:57.423316 [ 8268 ] {bd99910d-54e0-49c1-a566-6cb37b5a390b} executeQuery: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47970) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:57.442367 [ 8268 ] {bd99910d-54e0-49c1-a566-6cb37b5a390b} TCPHandler: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:57.624519 [ 16283 ] {21bbbd74-a51c-458f-adcf-fdd02bc15982} executeQuery: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47996) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:57.633731 [ 16283 ] {21bbbd74-a51c-458f-adcf-fdd02bc15982} TCPHandler: Code: 15. DB::Exception: Cannot add column `value1`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:57.819623 [ 8268 ] {1546aead-0d4c-47ea-91e2-41e9386f560d} executeQuery: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48024) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:57.845418 [ 8268 ] {1546aead-0d4c-47ea-91e2-41e9386f560d} TCPHandler: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:57.845705 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:57.860774 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:58.129298 [ 2818 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:58.163026 [ 2824 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:58.326615 [ 2847 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:58.944958 [ 18986 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:39:59.132697 [ 2887 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:59.155167 [ 17479 ] {70346833-4e7f-4a6a-ab77-4d61f54b8f7e} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48074) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:59.159105 [ 17479 ] {70346833-4e7f-4a6a-ab77-4d61f54b8f7e} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:59.167013 [ 2890 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:59.272672 [ 8268 ] {19623a7b-54e1-4631-84a8-bd20ca4c6161} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48088) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:59.278461 [ 8268 ] {19623a7b-54e1-4631-84a8-bd20ca4c6161} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:59.333956 [ 2794 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:39:59.395985 [ 16283 ] {48c0cf2c-a972-4027-b43c-ca0dfb0bf5fd} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48148) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:39:59.431122 [ 16283 ] {48c0cf2c-a972-4027-b43c-ca0dfb0bf5fd} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.060460 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.124837 [ 17479 ] {e312a54f-f288-4e4f-847b-8cf48c03d3e6} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000019 */ CREATE TABLE test_5.parsing_with_names UUID 'aa4cff38-241f-4582-895e-d15c162dcd00' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.130978 [ 18928 ] {714942f1-932c-4d67-9b37-34cb7076a630} executeQuery: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48212) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 ADD COLUMN value5 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.134632 [ 2940 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:00.141570 [ 18928 ] {714942f1-932c-4d67-9b37-34cb7076a630} TCPHandler: Code: 15. DB::Exception: Cannot add column `value5`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.169898 [ 2942 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:00.178239 [ 18986 ] {78b22595-0ff4-4a60-8fa6-39973560fc98} executeQuery: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48230) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value2 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.200599 [ 18986 ] {78b22595-0ff4-4a60-8fa6-39973560fc98} TCPHandler: Code: 15. DB::Exception: Cannot add column `value2`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.270105 [ 17479 ] {e312a54f-f288-4e4f-847b-8cf48c03d3e6} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48174) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.275129 [ 17479 ] {e312a54f-f288-4e4f-847b-8cf48c03d3e6} TCPHandler: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.339048 [ 2950 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:00.925833 [ 17479 ] {6c8358c6-9726-4a9b-b451-e9ca31386475} executeQuery: Code: 36. DB::Exception: Cannot drop column value5 because it's affected by mutation with ID '0000000004' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000004'". (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48276) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_1 DROP COLUMN value5 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000002c541a9a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000002c4b058d 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a671a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180212 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:40:00.948019 [ 17479 ] {6c8358c6-9726-4a9b-b451-e9ca31386475} TCPHandler: Code: 36. DB::Exception: Cannot drop column value5 because it's affected by mutation with ID '0000000004' which is not finished yet. Wait this mutation, or KILL it with command "KILL MUTATION WHERE mutation_id = '0000000004'". (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const::$_0::operator()(String const&, String const&, String const&) const @ 0x000000002c541a9a 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkDropCommandDoesntAffectInProgressMutations(DB::AlterCommand const&, std::map, std::allocator>> const&, std::shared_ptr) const @ 0x000000002c4b058d 5. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a671a 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180212 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:40:01.103619 [ 8268 ] {ac5b4efa-83bd-4156-8e3b-34f342311c40} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48326) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactStringsEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:01.137279 [ 8268 ] {ac5b4efa-83bd-4156-8e3b-34f342311c40} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:01.179553 [ 2990 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:01.179641 [ 2982 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:01.196252 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:01.336091 [ 18922 ] {53ef946f-5a2e-4ab6-9560-4d1d4f821db4} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48294) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 DROP COLUMN value3 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:01.345385 [ 18922 ] {53ef946f-5a2e-4ab6-9560-4d1d4f821db4} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:01.346818 [ 3006 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:01.962919 [ 17478 ] {ebb82766-6748-4754-819b-926676d81b2c} executeQuery: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48366) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_3 ADD COLUMN value3 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:01.978525 [ 17478 ] {ebb82766-6748-4754-819b-926676d81b2c} TCPHandler: Code: 15. DB::Exception: Cannot add column `value3`: column with this name already exists. (DUPLICATE_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/AlterCommands.cpp:1321: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6152bb 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:02.187675 [ 3043 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:02.187917 [ 3056 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:02.335806 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:02.341526 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:02.348642 [ 3042 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:02.376539 [ 8268 ] {21996525-189f-41b5-8314-658c95b07965} executeQuery: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48408) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: ALTER TABLE concurrent_alter_add_drop_2 ADD COLUMN value1 UInt32 DEFAULT 42 SETTINGS replication_alter_partitions_sync=0), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:02.388325 [ 8268 ] {21996525-189f-41b5-8314-658c95b07965} TCPHandler: Code: 517. DB::Exception: Metadata on replica is not up to date with common metadata in Zookeeper. It means that this replica still not applied some of previous alters. Probably too many alters executing concurrently (highly not recommended). You can retry this error. (CANNOT_ASSIGN_ALTER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:6345: DB::StorageReplicatedMergeTree::alter(DB::AlterCommands const&, std::shared_ptr, std::unique_lock&) @ 0x000000002bb644bf 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:210: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180266 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:40:02.392352 [ 8268 ] {21996525-189f-41b5-8314-658c95b07965} TCPHandler: Client has gone away. 2025.10.23 23:40:03.148546 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:03.192864 [ 3085 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:03.193530 [ 3090 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:03.350846 [ 3089 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:03.621066 [ 8268 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:03.800209 [ 17479 ] {ca4fd159-d926-4f37-849a-b5727685832a} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: /* ddl_entry=query-0000000021 */ CREATE TABLE test_5.parsing_with_names UUID '06708b1a-7aa5-4ef9-b310-a0e04dd73941' (`c` FixedString(16), `a` DateTime('Asia/Dubai'), `b` String) ENGINE = Memory), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:03.899573 [ 17479 ] {ca4fd159-d926-4f37-849a-b5727685832a} executeQuery: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48478) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: CREATE TABLE parsing_with_names(c FixedString(16), a DateTime('Asia/Dubai'), b String) ENGINE=Memory()), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:03.921356 [ 17479 ] {ca4fd159-d926-4f37-849a-b5727685832a} TCPHandler: Code: 57. DB::Exception: Table test_5.parsing_with_names already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 9. ./build_docker/./src/Interpreters/DDLWorker.cpp:498: DB::DDLWorker::tryExecuteQuery(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x00000000286919b0 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DDLWorker::processTask(DB::DDLTaskBase&, std::shared_ptr const&) @ 0x000000002868d693 11. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:331: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db59c2 12. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:04.196564 [ 3127 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:04.196997 [ 3088 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:04.352949 [ 3126 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:04.658171 [ 3389 ] {6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac::all_0_5_11_17} 6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac::all_0_5_11_17 (MergeFromLogEntryTask): Code: 40. DB::Exception: Part all_0_5_11_17 from 3 has different columns hash (it may rarely happen on race condition with KILL MUTATION). (CHECKSUM_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)). Data after merge is not byte-identical to data on another replicas. There could be several reasons: 1. Using newer version of compression library after server update. 2. Using another compression method. 3. Non-deterministic compression algorithm (highly unlikely). 4. Non-deterministic merge algorithm due to logical error in code. 5. Data corruption in memory due to bug in code. 6. Data corruption in memory due to hardware issue. 7. Manual modification of source data after server startup. 8. Manual modification of checksums stored in ZooKeeper. 9. Part format related settings like 'enable_mixed_granularity_parts' are different on different replicas. We will download merged part from replica to force byte-identical result. List of files in local parts: count.txt: 6 (7d05f7c33141ac772ce426af640291c9) data.bin: 409097 (a85c9f0bc5dd07d4ab8072e3d4484c7a) data.cmrk3: 284 (3bdb4e05504fc2451e9b9360be7eb965) primary.cidx: 90 (12ea71407e33aa8073b10f6b3b0c4f9b) serialization.json: 386 (afb5be1cacf48cb44e25bf7bb2bfcab9) 2025.10.23 23:40:04.683369 [ 17478 ] {b669585f-d23c-4f7f-91bc-f1b7e0d7d2a3} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34400) (comment: 00167_parallel_parsing_with_names_and_types.sh) (in query: SELECT URLRegions as d, toTimeZone(ClientEventTime, 'Asia/Dubai') as a, MobilePhoneModel as b, ParamPrice as e, ClientIP6 as c FROM test.hits LIMIT 5000 Format JSONCompactStringsEachRowWithNamesAndTypes), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:04.697297 [ 17478 ] {b669585f-d23c-4f7f-91bc-f1b7e0d7d2a3} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'ParamPrice' in scope SELECT URLRegions AS d, toTimeZone(ClientEventTime, 'Asia/Dubai') AS a, MobilePhoneModel AS b, ParamPrice AS e, ClientIP6 AS c FROM test.hits LIMIT 5000. Maybe you meant: ['ParamSumPrice']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 10. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 11. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 12. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 13. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 14. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:40:04.710954 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:05.199867 [ 3163 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:05.200359 [ 3160 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:05.520661 [ 3168 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:05.861845 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:06.202742 [ 3181 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:06.203624 [ 3139 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:06.523800 [ 3166 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:06.943942 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:07.211195 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:07.211642 [ 3216 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:07.412049 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:07.526896 [ 3222 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:07.835207 [ 18099 ] {b2f2cab2-2f8e-450e-bc7b-d6b875c4a539} executeQuery: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34456) (comment: 00042_any_left_join.sql) (in query: SELECT EventDate, hits, visits FROM ( SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate ) ANY LEFT JOIN ( SELECT StartDate AS EventDate, sum(Sign) AS visits FROM test.visits GROUP BY EventDate ) USING EventDate ORDER BY hits DESC LIMIT 10 SETTINGS joined_subquery_requires_alias = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c8564 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4eee 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:40:07.862612 [ 18099 ] {b2f2cab2-2f8e-450e-bc7b-d6b875c4a539} TCPHandler: Code: 47. DB::Exception: Unknown expression identifier 'EventDate' in scope SELECT EventDate, count() AS hits FROM test.hits GROUP BY EventDate. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3783: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837236f 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5172: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4e79 10. ./contrib/llvm-project/libcxx/include/vector:1491: DB::QueryAnalyzer::resolveJoin(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c8564 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::QueryAnalyzer::resolveQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&, DB::QueryExpressionsAliasVisitor&) @ 0x00000000283c4eee 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283656a9 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:40:07.988039 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:08.217548 [ 3235 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:08.217683 [ 3239 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:08.401226 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:08.530145 [ 3241 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:09.154801 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:09.221996 [ 3243 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:09.222351 [ 3274 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:09.564253 [ 3276 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:09.934808 [ 18099 ] {e249e137-cb4a-4bf0-8125-aa0d2706c779} executeQuery: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT CAST(EventTime, 'DateTime(\'Asia/Dubai\')') FROM test.hits ORDER BY EventTime DESC LIMIT 10. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:34508) (comment: 00011_sorting.sql) (in query: SELECT EventTime::DateTime('Asia/Dubai') FROM test.hits ORDER BY EventTime DESC LIMIT 10 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:40:09.946898 [ 18099 ] {e249e137-cb4a-4bf0-8125-aa0d2706c779} TCPHandler: Code: 47. DB::Exception: Unknown expression or function identifier 'EventTime' in scope SELECT CAST(EventTime, 'DateTime(\'Asia/Dubai\')') FROM test.hits ORDER BY EventTime DESC LIMIT 10. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, char const*&&, String&, String const&, String&&, String&&) @ 0x00000000283d11f5 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3684: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028374b74 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:40:10.224773 [ 2780 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:10.225459 [ 2782 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:10.297323 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:10.567476 [ 2811 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:11.227396 [ 2833 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:11.228911 [ 2826 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:11.510984 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:11.570232 [ 2835 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:12.230405 [ 2860 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:12.231821 [ 2863 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:12.573265 [ 2882 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:12.658068 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:12.705494 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:13.236620 [ 2892 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:13.237555 [ 2877 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:13.507512 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:13.576576 [ 2911 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:13.793855 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:14.239875 [ 2902 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.241056 [ 2919 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.580432 [ 2906 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:14.944859 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:15.243405 [ 2932 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:15.243996 [ 2942 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:15.583965 [ 2950 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:16.013350 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:16.246376 [ 2966 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:16.246985 [ 2955 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:16.587675 [ 2969 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:17.005517 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:17.249241 [ 2990 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:17.249683 [ 2982 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:17.590971 [ 2992 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:17.783464 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:18.067568 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:18.252074 [ 3007 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:18.253152 [ 3010 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:18.594284 [ 3022 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:18.673919 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:19.172442 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:19.255854 [ 3015 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:19.256610 [ 3037 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:19.461811 [ 17479 ] {1e4d4b18-9cc5-4634-a88b-cd910ad6df28} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column key): (while reading from part /var/lib/clickhouse/store/6f7/6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac/all_0_5_11_19/ in table test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac) located on disk default of type local, from mark 6 with max_rows_to_read = 24576): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49686) (comment: 01079_parallel_alter_add_drop_column_zookeeper.sh) (in query: SELECT * FROM merge(currentDatabase(), 'concurrent_alter_add_drop_') FORMAT Null), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b585216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769d30 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CachedCompressedReadBuffer::nextImpl() @ 0x000000002c80d03d 15. DB::ReadBuffer::next() @ 0x000000000b52caeb 16. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000cd78061 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba20d0 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dec1114 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 2025.10.23 23:40:19.468025 [ 17479 ] {1e4d4b18-9cc5-4634-a88b-cd910ad6df28} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column key): (while reading from part /var/lib/clickhouse/store/6f7/6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac/all_0_5_11_19/ in table test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac) located on disk default of type local, from mark 6 with max_rows_to_read = 24576): While executing MergeTreeSelect(pool: ReadPoolInOrder, algorithm: InOrder). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. DB::ReadBuffer::readStrict(char*, unsigned long) @ 0x000000000b585216 13. ./build_docker/./src/Compression/CompressedReadBufferBase.cpp:0: DB::CompressedReadBufferBase::readCompressedData(unsigned long&, unsigned long&, bool) @ 0x0000000027769d30 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::CachedCompressedReadBuffer::nextImpl() @ 0x000000002c80d03d 15. DB::ReadBuffer::next() @ 0x000000000b52caeb 16. DB::ReadBuffer::readBig(char*, unsigned long) @ 0x000000000cd78061 17. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba20d0 18. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 20. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 22. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 23. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 24. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 25. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:53: DB::MergeTreeInOrderSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002dec1114 26. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 27. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 28. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 29. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 30. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 31. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 2025.10.23 23:40:19.613116 [ 3034 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:20.210637 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:20.259232 [ 3046 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:20.259748 [ 3042 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:20.616421 [ 3055 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:21.262295 [ 3069 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:21.262981 [ 3079 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:21.375291 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:21.619143 [ 3081 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:22.264990 [ 3092 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:22.265810 [ 3100 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:22.624455 [ 3112 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:22.659490 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:22.996798 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:23.268975 [ 3113 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:23.269239 [ 3088 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:23.627868 [ 3124 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:23.824535 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:23.840445 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:24.272784 [ 3144 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:24.279957 [ 3107 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:24.631808 [ 3145 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:25.086661 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:25.276786 [ 3171 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:25.282926 [ 3156 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:25.635671 [ 3168 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:26.200963 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:26.279662 [ 3181 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:26.287030 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:26.638345 [ 3194 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.283497 [ 3177 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.289668 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:27.405365 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:27.641033 [ 3214 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:28.138931 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:28.286715 [ 3226 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:28.292580 [ 3201 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:28.644425 [ 3233 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:28.711509 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:28.950177 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:29.290217 [ 3242 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:29.295739 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:29.735671 [ 3247 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:30.038754 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:30.293723 [ 3268 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:30.299565 [ 3274 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:30.740502 [ 2773 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:31.117792 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:31.296781 [ 3261 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:31.302641 [ 3276 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:31.744790 [ 2803 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:32.299655 [ 2777 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:32.305413 [ 2788 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:32.452651 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:32.748252 [ 2812 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:33.298754 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:33.302598 [ 2808 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:33.308582 [ 2815 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:33.557208 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:33.751500 [ 2827 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:34.136619 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:34.306409 [ 2834 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:34.312247 [ 2830 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:34.652376 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:34.755190 [ 2843 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:35.309378 [ 2844 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:35.315668 [ 2857 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:35.661912 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:35.759812 [ 2866 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:36.313067 [ 2864 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:36.319112 [ 2887 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:36.812528 [ 2853 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:36.923766 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:37.316403 [ 2880 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:37.322348 [ 2794 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:37.983712 [ 2917 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:38.006252 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:38.319324 [ 2921 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:38.325180 [ 2936 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:38.440504 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:38.986568 [ 2929 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:39.099012 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:39.322414 [ 2946 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:39.328341 [ 2935 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:39.337048 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:39.989302 [ 2957 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:40.146058 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:40.327350 [ 2972 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:40.331577 [ 2973 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:40.991967 [ 2956 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:41.178836 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:41.330255 [ 2988 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:41.334671 [ 2986 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:41.995271 [ 3003 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:42.296095 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:42.333268 [ 3010 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:42.337519 [ 3000 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:42.998890 [ 3015 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:43.338801 [ 3041 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:43.340592 [ 3032 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:43.434071 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:43.635292 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:44.002110 [ 3047 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:44.342180 [ 3055 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:44.343830 [ 3062 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:44.437254 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:44.671383 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:45.005335 [ 3064 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:45.355379 [ 3080 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:45.355844 [ 3075 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:45.780791 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:46.009041 [ 3078 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:46.359705 [ 3097 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:46.379876 [ 3098 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:46.930568 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:47.011792 [ 3105 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:47.362979 [ 3116 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:47.382586 [ 3113 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:48.014552 [ 3133 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:48.040311 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:48.368245 [ 3143 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:48.385582 [ 3144 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:48.794083 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:49.017853 [ 3158 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:49.103566 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:49.371276 [ 3176 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:49.388079 [ 3168 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:49.723117 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:50.021260 [ 3192 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:50.142020 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:50.373888 [ 3202 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:50.390819 [ 3197 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:51.024636 [ 3208 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:51.376711 [ 3219 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:51.388298 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:51.404388 [ 3217 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:52.027936 [ 3240 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:52.384343 [ 3232 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:52.408047 [ 3221 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:52.547357 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:52.719186 [ 18965 ] {5b982d4f-14c7-4d67-8885-0f4eaf45643d} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40618) (comment: 03171_function_to_subcolumns_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_qtmmr1n4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:40:52.721861 [ 18965 ] {5b982d4f-14c7-4d67-8885-0f4eaf45643d} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:52.799026 [ 15589 ] {381db98f-018d-432b-a459-a2242bdd5dbd} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60116) (comment: 03171_function_to_subcolumns_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_qtmmr1n4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:40:52.801397 [ 15589 ] {381db98f-018d-432b-a459-a2242bdd5dbd} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:52.879328 [ 18922 ] {e297a962-cc80-4557-a6bb-a1fd40f9742b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60128) (comment: 03171_function_to_subcolumns_fuzzer.sql) (in query: DROP DATABASE IF EXISTS test_qtmmr1n4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:40:52.892954 [ 18922 ] {e297a962-cc80-4557-a6bb-a1fd40f9742b} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:53.031353 [ 3264 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:53.388180 [ 3250 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:53.412423 [ 3257 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:53.739736 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:53.969866 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:54.034473 [ 3283 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:54.391434 [ 2804 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:54.422320 [ 2806 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:54.916903 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:55.037690 [ 2782 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:55.065960 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:55.394932 [ 2793 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:55.428499 [ 2811 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:56.040810 [ 2787 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:56.231340 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:56.397959 [ 2820 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:56.430986 [ 2819 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:57.044569 [ 2844 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:57.400953 [ 2841 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:57.415924 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:57.434035 [ 2867 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:58.047929 [ 2874 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:58.404239 [ 2882 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:58.437239 [ 2865 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:58.538649 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:40:59.051152 [ 2892 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:59.071455 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:59.407479 [ 2886 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:59.440579 [ 2901 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:40:59.696459 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:00.053842 [ 2906 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:00.091412 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:00.410154 [ 2939 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:00.452279 [ 2941 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:00.810003 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:01.056691 [ 2944 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:01.413522 [ 2967 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:01.505597 [ 2961 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:01.993694 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:02.059560 [ 2920 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:02.416363 [ 2783 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:02.508871 [ 2987 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:02.970215 [ 17478 ] {36fc1dec-b452-47c0-9241-83fcc2275915} executeQuery: Code: 48. DB::Exception: Function sum does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47824) (comment: 02922_respect_nulls_extensive.sql) (in query: -- Unsupported functions should throw in the server SELECT number, sum (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265ba705 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b80c4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b69f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fb87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:41:02.996568 [ 17478 ] {36fc1dec-b452-47c0-9241-83fcc2275915} TCPHandler: Code: 48. DB::Exception: Function sum does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265ba705 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b80c4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b69f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fb87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:41:03.060645 [ 17478 ] {1a158851-a61f-4970-a410-257d7bf2b2ec} executeQuery: Code: 48. DB::Exception: Function avg does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47824) (comment: 02922_respect_nulls_extensive.sql) (in query: SELECT number, avgIf (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265ba705 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b80c4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b69f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fb87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:41:03.061947 [ 2994 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:03.064839 [ 17478 ] {1a158851-a61f-4970-a410-257d7bf2b2ec} TCPHandler: Code: 48. DB::Exception: Function avg does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265ba705 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b80c4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b69f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fb87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:41:03.069434 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:03.139867 [ 17478 ] {f837bbd1-4382-496e-9338-cd9d1f3d0d97} executeQuery: Code: 48. DB::Exception: Function any_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47824) (comment: 02922_respect_nulls_extensive.sql) (in query: -- Same for double RESPECT NULLS SELECT number, first_value_respect_nulls (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265ba705 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b80c4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b69f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fb87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:41:03.149682 [ 17478 ] {f837bbd1-4382-496e-9338-cd9d1f3d0d97} TCPHandler: Code: 48. DB::Exception: Function any_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265ba705 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b80c4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b69f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fb87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:41:03.226529 [ 17478 ] {ee79ff00-62c2-45c3-ac05-5c33f66205df} executeQuery: Code: 48. DB::Exception: Function anyLast_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47824) (comment: 02922_respect_nulls_extensive.sql) (in query: SELECT number, last_value_respect_nulls (number) RESPECT NULLS over (order by number) from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265ba705 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b80c4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b69f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fb87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:41:03.229271 [ 17478 ] {ee79ff00-62c2-45c3-ac05-5c33f66205df} TCPHandler: Code: 48. DB::Exception: Function anyLast_respect_nulls does not support RESPECT NULLS. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getAssociatedFunctionByNullsAction(String const&, DB::NullsAction) const @ 0x00000000265ba705 5. ./contrib/llvm-project/libcxx/include/optional:344: DB::AggregateFunctionFactory::tryGetProperties(String, DB::NullsAction) const @ 0x00000000265b80c4 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b69f7 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fb87 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 14. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 17. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 18. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 22. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 23. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 25. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 26. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 27. asan_thread_start(void*) @ 0x000000000aa47059 28. ? @ 0x00007f7519d19ac3 29. ? @ 0x00007f7519dab850 2025.10.23 23:41:03.419246 [ 3007 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:03.518521 [ 3000 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:04.064963 [ 3014 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:04.155777 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:04.157411 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:04.422848 [ 3018 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:04.521728 [ 3019 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:05.067955 [ 3040 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:05.178867 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:05.311368 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:05.427601 [ 3042 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:05.524896 [ 3048 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:06.071029 [ 3070 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:06.376199 [ 15589 ] {1ce3127f-7191-4c38-8c3b-a09aa26838bb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=731). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43268) (comment: 00559_filter_array_generic.sql) (in query: SELECT arrayJoin([[[1], [2]], [[1]]]) AS x WHERE length(x) = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:41:06.394702 [ 15589 ] {1ce3127f-7191-4c38-8c3b-a09aa26838bb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=731). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:41:06.430848 [ 3060 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:06.528622 [ 3071 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:06.541023 [ 18928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:07.074351 [ 3090 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:07.391696 [ 3387 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f031c251-ff48-4808-844a-5edfe9b82eeb::202510_1_129_94}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:07.499265 [ 3093 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:07.537078 [ 3096 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:08.037594 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:08.077682 [ 3109 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:08.501809 [ 3120 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:08.548228 [ 3088 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:09.080857 [ 3130 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:09.153726 [ 18928 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:09.298231 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:09.505275 [ 3140 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:09.552101 [ 3128 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:10.084016 [ 3150 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:10.382587 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:10.509752 [ 3156 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:10.555175 [ 3164 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:10.610404 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:11.086974 [ 3188 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:11.512841 [ 3138 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:11.558097 [ 3182 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:11.802057 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:12.089975 [ 3191 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:12.516563 [ 3207 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:12.561606 [ 3206 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:13.092966 [ 3220 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:13.127841 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:13.519531 [ 3225 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:13.564764 [ 3223 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:14.095955 [ 3238 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:14.268110 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:14.438488 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:14.522070 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:14.567613 [ 3244 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:15.099023 [ 3269 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:15.510460 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:15.524484 [ 3263 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:15.538844 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:15.570087 [ 3282 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:16.101664 [ 3228 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:16.527808 [ 3272 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:16.573526 [ 2772 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:16.785795 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:17.104490 [ 2778 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:17.533078 [ 2777 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:17.581608 [ 2789 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:18.009991 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:18.107581 [ 2813 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:18.536354 [ 2784 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:18.584965 [ 2831 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:19.111264 [ 2825 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:19.273297 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:19.543098 [ 2834 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:19.582744 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:19.587946 [ 2840 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:20.114772 [ 2830 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:20.485009 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:20.545762 [ 2844 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:20.590575 [ 2856 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:20.649680 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:21.117748 [ 2875 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:21.548600 [ 2848 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:21.583001 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:21.593473 [ 2879 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:22.140411 [ 2898 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:22.551582 [ 2900 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:22.597368 [ 2897 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:22.740824 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:23.145231 [ 2903 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:23.554424 [ 2845 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:23.600248 [ 2911 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:23.949692 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:24.148203 [ 2919 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:24.562244 [ 2912 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:24.602696 [ 2885 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:24.758548 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:25.049639 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:25.150539 [ 2942 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:25.564812 [ 2935 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:25.604541 [ 2944 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:25.858780 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:26.101027 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:26.152695 [ 2961 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:26.567971 [ 2973 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:26.607272 [ 2965 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:27.159941 [ 2987 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:27.164129 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:27.570620 [ 2985 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:27.611188 [ 2995 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:28.162994 [ 3006 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:28.210281 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:28.577096 [ 3007 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:28.614220 [ 3000 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:29.166722 [ 3027 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:29.361231 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:29.580210 [ 3021 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:29.616839 [ 3033 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:30.007840 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:30.169765 [ 3041 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:30.583182 [ 3002 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:30.619862 [ 3040 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:30.622790 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:30.976178 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:31.173409 [ 3053 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:31.585659 [ 3054 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:31.623097 [ 3057 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:31.809912 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:32.175948 [ 3061 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:32.588515 [ 3068 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:32.626435 [ 3075 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:33.103832 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:33.242672 [ 3086 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:33.591107 [ 3089 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:33.631829 [ 3078 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:34.246246 [ 3104 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:34.381265 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:34.594496 [ 3115 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:34.637417 [ 3102 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:35.144464 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:35.249356 [ 3127 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:35.599226 [ 3108 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:35.646790 [ 3130 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:35.699897 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:36.122062 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:36.252537 [ 3134 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:36.601919 [ 3135 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:36.649491 [ 3144 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:36.845664 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:37.259769 [ 3170 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:37.605903 [ 3171 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:37.652839 [ 3136 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:37.954372 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:38.263105 [ 3153 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:38.609263 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:38.698105 [ 3192 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:39.068165 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:39.265932 [ 3202 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:39.611969 [ 3204 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:39.701802 [ 3211 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:40.098241 [ 18099 ] {b84b8730-010a-4433-9cd9-7eeb10c240cc} executeQuery: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38418) (comment: 01570_aggregator_combinator_simple_state.sql) (in query: -- non-SimpleAggregateFunction with countSimpleState(number) as c select toTypeName(c), c from numbers(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:58: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x00000000278ca9f0 5. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:35: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x0000000025f53ea7 6. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000025f53a13 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], 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&) @ 0x0000000025f9fccb 8. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.cpp:22: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025f9fbd7 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b9657 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b6b32 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4d47 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1151: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838d8fd 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838f223 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 27. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 2025.10.23 23:41:40.109667 [ 18099 ] {b84b8730-010a-4433-9cd9-7eeb10c240cc} TCPHandler: Code: 36. DB::Exception: Unsupported aggregate function count, supported functions are any,anyLast,min,max,sum,sumWithOverflow,groupBitAnd,groupBitOr,groupBitXor,sumMap,minMap,maxMap,groupArrayArray,groupArrayLastArray,groupUniqArrayArray,sumMappedArrays,minMappedArrays,maxMappedArrays. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/DataTypes/DataTypeCustomSimpleAggregateFunction.cpp:58: DB::DataTypeCustomSimpleAggregateFunction::checkSupportedFunctions(std::shared_ptr const&) @ 0x00000000278ca9f0 5. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:35: DB::AggregateFunctionSimpleState::createResultType(std::shared_ptr const&, DB::Array const&) @ 0x0000000025f53ea7 6. ./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.h:23: DB::AggregateFunctionSimpleState::AggregateFunctionSimpleState(std::shared_ptr, std::vector, std::allocator>> const&, DB::Array const&) @ 0x0000000025f53a13 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1460: std::shared_ptr std::allocate_shared[abi:v15007], 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&) @ 0x0000000025f9fccb 8. ./build_docker/./src/AggregateFunctions/Combinators/AggregateFunctionSimpleState.cpp:22: DB::(anonymous namespace)::AggregateFunctionCombinatorSimpleState::transformAggregateFunction(std::shared_ptr const&, DB::AggregateFunctionProperties const&, std::vector, std::allocator>> const&, DB::Array const&) const @ 0x0000000025f9fbd7 9. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:0: DB::AggregateFunctionFactory::getImpl(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&, bool) const @ 0x00000000265b9657 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionFactory.cpp:124: DB::AggregateFunctionFactory::get(String const&, DB::NullsAction, std::vector, std::allocator>> const&, DB::Array const&, DB::AggregateFunctionProperties&) const @ 0x00000000265b6b32 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4d47 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:1151: DB::QueryAnalyzer::tryResolveIdentifierFromAliases(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838d8fd 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838f223 15. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 21. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 24. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 25. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 26. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 27. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 28. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 30. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 31. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 2025.10.23 23:41:40.186486 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:40.269242 [ 3210 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:40.286629 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:40.617853 [ 3226 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:40.705337 [ 3224 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:41.272942 [ 3239 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:41.385573 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:41.450850 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:41.621100 [ 3155 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:41.709017 [ 3238 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:42.279482 [ 3252 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:42.622667 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:42.624035 [ 3268 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:42.793906 [ 3277 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:43.283048 [ 2775 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:43.634055 [ 3261 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:43.786130 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:43.797300 [ 3183 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:44.286622 [ 2792 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:44.637277 [ 3212 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:44.836908 [ 2799 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:44.959258 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:45.289627 [ 2797 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:45.478225 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:45.553365 [ 18099 ] {42742369-d139-4728-aa81-d19e1c16d77a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38466) (comment: 01524_do_not_merge_across_partitions_select_final.sql) (in query: INSERT INTO select_final SELECT toDate('2000-01-01'), number, '' FROM numbers(2);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d362b87 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:41:45.583717 [ 18099 ] {42742369-d139-4728-aa81-d19e1c16d77a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d362b87 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:41:45.641949 [ 2817 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:45.869650 [ 2831 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:46.106021 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:46.292920 [ 2833 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:46.471949 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:46.645499 [ 2837 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:46.872671 [ 2824 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:47.252279 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:47.295733 [ 2844 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:47.405875 [ 18099 ] {609a9fe9-aa97-4242-909a-0fd6953375cc} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42484) (comment: 02875_fix_column_decimal_serialization.sql) (in query: SELECT count(), min(length(c.d)) AS minExpr, min(dcount) AS minAlias, max(length(c.d)) AS maxExpr, max(dcount) AS maxAlias, b FROM max_length_alias_14053__fuzz_45 GROUP BY b;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ac02a7 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:41:47.423500 [ 18099 ] {609a9fe9-aa97-4242-909a-0fd6953375cc} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: DB::MergeTreeReaderWide::addStream(DB::ISerialization::SubstreamPath const&, String const&) @ 0x000000002c816e11 10. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: void std::__function::__policy_invoker::__call_impl const&)::$_0, void (DB::ISerialization::SubstreamPath const&)>>(std::__function::__policy_storage const*, DB::ISerialization::SubstreamPath const&) @ 0x000000002c818c75 11. ./src/DataTypes/Serializations/ISerialization.h:225: DB::SerializationArray::enumerateStreams(DB::ISerialization::EnumerateStreamsSettings&, std::function const&, DB::ISerialization::SubstreamData const&) const @ 0x0000000027ac02a7 12. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:106: DB::ISerialization::enumerateStreams(std::function const&, std::shared_ptr const&, COW::immutable_ptr const&) const @ 0x0000000027aa9405 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:100: DB::MergeTreeReaderWide::addStreams(DB::NameAndTypePair const&, std::shared_ptr const&) @ 0x000000002c8129f5 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderWide.cpp:0: 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) @ 0x000000002c8120ca 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: 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&) @ 0x000000002c5ffae6 16. ./build_docker/./src/Storages/MergeTree/MergeTreeDataPartWide.cpp:43: DB::MergeTreeDataPartWide::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5f766e 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 19. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 21. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 26. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 27. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 28. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:41:47.648513 [ 2867 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:47.875702 [ 2871 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:48.299034 [ 2864 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:48.453958 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:48.501358 [ 18099 ] {59a07bb7-a0ff-4ac0-93a8-08c326dffed0} executeQuery: Code: 10. DB::Exception: Not found column x in block __table1.dummy UInt8 UInt8(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42492) (comment: 01527_bad_aggregation_in_lambda.sql) (in query: SELECT arrayMap(x -> x * sum(x), range(10));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1204: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000002826fad2 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000029448476 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000002943b056 7. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000029432a7b 8. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002942ddd2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43d9e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:48.519379 [ 18099 ] {59a07bb7-a0ff-4ac0-93a8-08c326dffed0} TCPHandler: Code: 10. DB::Exception: Not found column x in block __table1.dummy UInt8 UInt8(size = 0). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Interpreters/ActionsDAG.cpp:1204: DB::ActionsDAG::appendInputsForUnusedColumns(DB::Block const&) @ 0x000000002826fad2 5. ./build_docker/./src/Planner/Planner.cpp:0: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000029448476 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x000000002943b056 7. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000029432a7b 8. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002942ddd2 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43d9e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:48.651737 [ 2888 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:48.943594 [ 2890 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:49.302136 [ 2892 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:49.481859 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:49.654920 [ 2904 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:49.951379 [ 2907 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:49.970085 [ 18099 ] {5d8d5319-e667-4b21-bbbb-66ed650b4bd2} executeQuery: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_13.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42514) (comment: 03063_analyzer_multi_join_wrong_table_specifier.sql) (in query: SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE (t1.d >= now());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002844aee6 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002843ed14 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002843fb70 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443da1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028441934 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443dc7 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028441934 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443dc7 11. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1526: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000028447a54 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838f38a 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 2025.10.23 23:41:50.028033 [ 18099 ] {5d8d5319-e667-4b21-bbbb-66ed650b4bd2} TCPHandler: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_13.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k INNER JOIN t2 ON t2.x = t1.x WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002844aee6 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002843ed14 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002843fb70 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443da1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028441934 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443dc7 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028441934 10. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443dc7 11. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1526: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000028447a54 12. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838f38a 13. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 2025.10.23 23:41:50.269508 [ 18099 ] {83567bdb-2eb5-42ee-99f2-ca15406ac90e} executeQuery: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_13.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42514) (comment: 03063_analyzer_multi_join_wrong_table_specifier.sql) (in query: SELECT * FROM t1 INNER JOIN s ON t1.k = s.k WHERE (t1.d >= now());), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002844aee6 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002843ed14 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002843fb70 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443da1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028441934 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443dc7 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1526: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000028447a54 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838f38a 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:41:50.276796 [ 18099 ] {83567bdb-2eb5-42ee-99f2-ca15406ac90e} TCPHandler: Code: 47. DB::Exception: Identifier 't1.d' cannot be resolved from table with name test_13.t1. In scope SELECT * FROM t1 INNER JOIN s ON t1.k = s.k WHERE t1.d >= now(). Maybe you meant: ['t1.k']. (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String const&, String&, String&&, String&&) @ 0x000000002844aee6 4. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:839: DB::IdentifierResolver::tryResolveIdentifierFromStorage(DB::Identifier const&, std::shared_ptr const&, DB::AnalysisTableExpressionData const&, DB::IdentifierResolveScope&, unsigned long, bool) @ 0x000000002843ed14 5. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:0: DB::IdentifierResolver::tryResolveIdentifierFromTableExpression(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x000000002843fb70 6. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443da1 7. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1002: DB::IdentifierResolver::tryResolveIdentifierFromJoin(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028441934 8. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1493: DB::IdentifierResolver::tryResolveIdentifierFromJoinTreeNode(DB::IdentifierLookup const&, std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028443dc7 9. ./build_docker/./src/Analyzer/Resolve/IdentifierResolver.cpp:1526: DB::IdentifierResolver::tryResolveIdentifierFromJoinTree(DB::IdentifierLookup const&, DB::IdentifierResolveScope&) @ 0x0000000028447a54 10. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::QueryAnalyzer::tryResolveIdentifier(DB::IdentifierLookup const&, DB::IdentifierResolveScope&, DB::IdentifierResolveSettings) @ 0x000000002838f38a 11. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372e79 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:2813: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839c88e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5475: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365a32 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:41:50.405378 [ 2931 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:50.614774 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:50.658614 [ 2927 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:50.687121 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:50.954801 [ 2936 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:51.408626 [ 2926 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:51.627830 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:51.662468 [ 2942 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:51.838730 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:51.960831 [ 2959 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:52.412211 [ 2960 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:52.665945 [ 2972 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:52.925516 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:52.963667 [ 2979 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:53.415809 [ 2783 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:53.669271 [ 2985 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:53.966912 [ 2994 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:53.991706 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:54.419095 [ 3000 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:54.672824 [ 2981 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:54.971606 [ 3027 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:55.155873 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:55.423382 [ 3009 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:55.675769 [ 3035 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:55.757426 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:55.974970 [ 3038 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:56.139646 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:56.426719 [ 3030 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:56.678705 [ 3046 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:56.832284 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:56.978421 [ 3048 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:57.300193 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:57.430760 [ 3059 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:57.682064 [ 3069 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:57.982405 [ 3091 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:58.422187 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:58.433678 [ 3095 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:58.685447 [ 3104 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:58.985775 [ 3101 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:59.446644 [ 3088 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:59.568127 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:41:59.688657 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:41:59.988634 [ 3140 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:00.449964 [ 3141 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:00.691875 [ 3103 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:00.713892 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:00.932175 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:00.991685 [ 3156 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.452892 [ 3168 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.695023 [ 3185 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.805722 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:01.962072 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:01.996823 [ 3189 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:02.456293 [ 3197 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:02.697857 [ 3211 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:02.845643 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:02.999681 [ 3219 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:03.460021 [ 3224 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:03.700787 [ 3234 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:03.820280 [ 18099 ] {d0ed1e50-b729-40fb-8976-16b9923e1135} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48168) (comment: 01508_partition_pruning_long_2.sh) (in query: INSERT INTO xMM SELECT toDateTime('2020-10-01 00:00:00', 'Asia/Istanbul') + number*60, 1, number FROM numbers(5000);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d361ab7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d192da3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:42:03.823691 [ 18099 ] {d0ed1e50-b729-40fb-8976-16b9923e1135} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=733). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d361ab7 7. ./build_docker/./src/Server/TCPHandler.cpp:621: DB::TCPHandler::runImpl() @ 0x000000002d192da3 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:42:03.971294 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:04.006191 [ 3240 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:04.463118 [ 3252 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:04.704676 [ 3258 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:05.009529 [ 3269 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:05.139095 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:05.465960 [ 3282 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:05.708607 [ 3260 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.013075 [ 3278 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.128110 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.431006 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:06.465335 [ 18099 ] {cfdd8043-189e-4aea-b190-550c7e18ced4} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59406) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from tDD where toDate(d)=toDate('2020-09-24');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:42:06.468718 [ 3283 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:06.487921 [ 18099 ] {cfdd8043-189e-4aea-b190-550c7e18ced4} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=15, jobs=15). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:42:06.712207 [ 2803 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.015810 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.111169 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.471121 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:07.597556 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:07.714943 [ 2776 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:08.018536 [ 2807 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:08.473189 [ 2827 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:08.736042 [ 2825 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:08.736686 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:09.021256 [ 2818 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.475492 [ 2858 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.738675 [ 2857 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:09.868831 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:10.023919 [ 2867 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:10.479251 [ 2848 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:10.741480 [ 2859 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:10.957089 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:11.026457 [ 2865 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:11.378349 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:11.482187 [ 2889 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:11.744026 [ 2892 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:11.966083 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:12.009162 [ 18099 ] {02f12a77-a609-4062-b1ff-418db03f28e3} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59492) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() FROM tDD WHERE toDate(d) = '2020-09-24';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:12.028949 [ 2909 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:12.028569 [ 18099 ] {02f12a77-a609-4062-b1ff-418db03f28e3} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:12.246562 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:12.485970 [ 2915 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:12.747524 [ 2931 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:13.018956 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:13.031416 [ 2802 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:13.488818 [ 2912 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:13.750808 [ 2930 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:14.035669 [ 2932 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:14.053927 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:14.506443 [ 2949 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:14.541085 [ 18099 ] {a6ca0fdb-d8da-4c22-9d93-ad411c7145e1} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37742) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() FROM tDD WHERE toYYYYMMDD(d) >= 20200923 and toDate(d) <= '2020-09-26';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:14.547910 [ 18099 ] {a6ca0fdb-d8da-4c22-9d93-ad411c7145e1} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:14.754188 [ 2947 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:15.065105 [ 2955 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:15.215260 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:15.509425 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:15.756932 [ 2971 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:16.068182 [ 2988 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:16.128221 [ 18099 ] {16c3b2d0-61a9-43ca-949c-c941886fd3fd} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/888/888fd814-7610-437b-a457-d6fbc28f8d9a/202010_5_5_0/ in table test_13.sDD (888fd814-7610-437b-a457-d6fbc28f8d9a) located on disk default of type local, from mark 0 with max_rows_to_read = 5000): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37758) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from sDD;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x000000002776b81f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000002776f5e1 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba20d0 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 2025.10.23 23:42:16.156623 [ 18099 ] {16c3b2d0-61a9-43ca-949c-c941886fd3fd} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/888/888fd814-7610-437b-a457-d6fbc28f8d9a/202010_5_5_0/ in table test_13.sDD (888fd814-7610-437b-a457-d6fbc28f8d9a) located on disk default of type local, from mark 0 with max_rows_to_read = 5000): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x000000002776b81f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000002776f5e1 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba20d0 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 22. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 23. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 25. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 26. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 27. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 29. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 30. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 31. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 2025.10.23 23:42:16.354701 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:16.482009 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:16.512605 [ 3006 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:16.759725 [ 2996 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:17.071462 [ 3016 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:17.435630 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:17.515444 [ 3019 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:17.618678 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:17.764308 [ 3038 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:18.075761 [ 3032 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:18.518477 [ 3056 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:18.618381 [ 18099 ] {d77bf2c6-cd25-4ea8-887a-37fb1329bf2f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/888/888fd814-7610-437b-a457-d6fbc28f8d9a/202010_6_6_0/ in table test_13.sDD (888fd814-7610-437b-a457-d6fbc28f8d9a) located on disk default of type local, from mark 0 with max_rows_to_read = 5000): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37786) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from sDD where toYYYYMM(toDateTime(intDiv(d,1000),'UTC')-1) = 202010;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x000000002776b81f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000002776f5e1 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba20d0 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7eff15 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 2025.10.23 23:42:18.641989 [ 18099 ] {d77bf2c6-cd25-4ea8-887a-37fb1329bf2f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=0): (while reading column d): (while reading from part /var/lib/clickhouse/store/888/888fd814-7610-437b-a457-d6fbc28f8d9a/202010_6_6_0/ in table test_13.sDD (888fd814-7610-437b-a457-d6fbc28f8d9a) located on disk default of type local, from mark 0 with max_rows_to_read = 5000): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000266054c2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026604ed4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x0000000026602407 9. ./build_docker/./src/IO/AsynchronousReadBufferFromFileDescriptor.cpp:62: DB::AsynchronousReadBufferFromFileDescriptor::asyncReadInto(char*, unsigned long, Priority) @ 0x00000000265ebedd 10. ./contrib/llvm-project/libcxx/include/future:1123: DB::AsynchronousReadBufferFromFileDescriptor::nextImpl() @ 0x00000000265ecad3 11. DB::ReadBuffer::next() @ 0x000000000b52caeb 12. ./src/IO/ReadBuffer.h:0: DB::CompressedReadBufferBase::readCompressedDataBlockForAsynchronous(unsigned long&, unsigned long&) @ 0x000000002776b81f 13. ./build_docker/./src/Compression/CompressedReadBufferFromFile.cpp:110: DB::CompressedReadBufferFromFile::readBig(char*, unsigned long) @ 0x000000002776f5e1 14. ./build_docker/./src/DataTypes/Serializations/SerializationNumber.cpp:222: DB::SerializationNumber::deserializeBinaryBulk(DB::IColumn&, DB::ReadBuffer&, unsigned long, double) const @ 0x0000000027ba20d0 15. ./build_docker/./src/DataTypes/Serializations/ISerialization.cpp:0: DB::ISerialization::deserializeBinaryBulkWithMultipleStreams(COW::immutable_ptr&, unsigned long, DB::ISerialization::DeserializeBinaryBulkSettings&, std::shared_ptr&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) const @ 0x0000000027aaaa7b 16. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::readData(unsigned long, COW::immutable_ptr&, unsigned long, DB::MergeTreeReaderStream&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>&, std::unordered_map::immutable_ptr, std::hash, std::equal_to, std::allocator::immutable_ptr>>>*) @ 0x000000002c7c672b 17. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.cpp:53: DB::MergeTreeReaderCompactSingleBuffer::readRows(unsigned long, unsigned long, bool, unsigned long, std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ff97e 18. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:118: DB::MergeTreeRangeReader::DelayedStream::finalize(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) @ 0x000000002c7ddf6a 19. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::startReadingChain(unsigned long, DB::MarkRanges&) @ 0x000000002c7f4653 20. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7f00a3 21. ./build_docker/./src/Storages/MergeTree/MergeTreeRangeReader.cpp:0: DB::MergeTreeRangeReader::read(unsigned long, DB::MarkRanges&) @ 0x000000002c7eff15 22. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:0: DB::MergeTreeReadTask::read(DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002c8414fb 23. ./src/Storages/MergeTree/MergeTreeSelectAlgorithms.h:38: DB::MergeTreeThreadSelectAlgorithm::readFromTask(DB::MergeTreeReadTask&, DB::MergeTreeReadTask::BlockSizeParams const&) @ 0x000000002de82774 24. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838799 25. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 26. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 27. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 28. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 29. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 30. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 31. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 2025.10.23 23:42:18.753676 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:18.770318 [ 3055 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:19.078837 [ 3048 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:19.091688 [ 18099 ] {602b940f-b903-41d3-b0d8-9b4de791df33} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37802) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from sDD where toYYYYMM(toDateTime(intDiv(d,1000),'UTC')-1) = 202010;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:42:19.098788 [ 18099 ] {602b940f-b903-41d3-b0d8-9b4de791df33} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=733). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:42:19.521655 [ 3061 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:19.772744 [ 3075 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:19.992724 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:20.082394 [ 3086 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:20.477938 [ 18099 ] {c08c8cf2-8f6b-4da3-a062-04a00f661b5f} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37828) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from sDD where toYYYYMM(toDateTime(intDiv(d,1000),'UTC')-1) = 202110;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:20.482622 [ 18099 ] {c08c8cf2-8f6b-4da3-a062-04a00f661b5f} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=10, jobs=10). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:20.525532 [ 3066 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:20.776257 [ 3100 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:21.085706 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:21.113529 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:21.529763 [ 3109 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:21.630188 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:21.779765 [ 3044 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:22.090076 [ 3122 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:22.377705 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:22.532427 [ 3131 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:22.541694 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:22.783563 [ 3128 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:22.860061 [ 18922 ] {42068e28-e21b-4cdd-95eb-cefe03155c2d} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.524791412 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43290) (comment: 00927_asof_join_long.sql) (in query: SELECT SUM(trades.price - tvs.tv) FROM (SELECT k, t, t as price FROM (SELECT toUInt32(number) AS k FROM numbers(1000)) keys CROSS JOIN (SELECT toUInt32(number * 10) AS t FROM numbers(3000)) trade_times SETTINGS join_algorithm = 'hash') trades ASOF LEFT JOIN tvs USING(k,t) SETTINGS join_algorithm = 'full_sorting_merge';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000278629ba 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027861124 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d365155 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364ae0 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 2025.10.23 23:42:22.912561 [ 18922 ] {42068e28-e21b-4cdd-95eb-cefe03155c2d} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.524791412 seconds, maximum: 60. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000278629ba 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027861124 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d365155 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364ae0 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 2025.10.23 23:42:23.092752 [ 3107 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:23.565800 [ 3163 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:23.569619 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:23.584909 [ 15589 ] {17bb0117-a2b0-4437-b4d4-61318875eb32} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54886) (comment: 00927_asof_join_long.sql) (in query: DROP DATABASE IF EXISTS test_nfggx8ml ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:42:23.599961 [ 15589 ] {17bb0117-a2b0-4437-b4d4-61318875eb32} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:23.786920 [ 3156 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:24.095856 [ 3184 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:24.463419 [ 17478 ] {1e54a979-d9db-4ea5-83c2-2675547fe383} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37378) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from sDD where d >= 1598918400000;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83f17a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:42:24.474827 [ 17478 ] {1e54a979-d9db-4ea5-83c2-2675547fe383} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=2): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83f17a 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:42:24.568839 [ 3173 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:24.791606 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:24.837712 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:25.099033 [ 3194 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:25.571834 [ 3196 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:25.794461 [ 3211 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:25.943055 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:26.101627 [ 3214 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:26.575084 [ 3222 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:26.709244 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:26.797082 [ 3223 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.052687 [ 18099 ] {59a55bb6-b10c-4cdf-a7d0-1c6197063928} executeQuery: Code: 57. DB::Exception: Table test_nzxdsmz6.d already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37408) (comment: 01505_distributed_local_type_conversion_enum.sql) (in query: CREATE TABLE d (x Enum8('abc' = 0, 'def' = 1, 'xyz' = 2)) ENGINE = Distributed(test_cluster_two_shards, currentDatabase(), t);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:42:27.073650 [ 18099 ] {59a55bb6-b10c-4cdf-a7d0-1c6197063928} TCPHandler: Code: 57. DB::Exception: Table test_nzxdsmz6.d already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:42:27.104880 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:27.105842 [ 3235 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.547925 [ 17478 ] {82a22407-3945-48e0-8fe7-5bb95988d9ae} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45730) (comment: 01505_distributed_local_type_conversion_enum.sql) (in query: DROP DATABASE IF EXISTS test_nzxdsmz6 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:42:27.554412 [ 17478 ] {82a22407-3945-48e0-8fe7-5bb95988d9ae} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.578425 [ 3237 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.649679 [ 18099 ] {6b35f996-7e78-4ab4-be45-7b0aaf855a94} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45744) (comment: 01505_distributed_local_type_conversion_enum.sql) (in query: DROP DATABASE IF EXISTS test_nzxdsmz6 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:42:27.714542 [ 18099 ] {6b35f996-7e78-4ab4-be45-7b0aaf855a94} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.797103 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:27.821873 [ 3242 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:28.109167 [ 3252 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:28.235792 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:28.582012 [ 3265 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:28.592084 [ 17478 ] {2ebddc17-9c94-4fdd-95b6-2d00e62f6f16} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37456) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where toStartOfDay(d) >= '2020-10-01 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:42:28.596039 [ 17478 ] {2ebddc17-9c94-4fdd-95b6-2d00e62f6f16} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:42:28.825170 [ 3277 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:29.112226 [ 3250 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:29.233020 [ 17479 ] {f5c48277-6124-438f-9156-6a0a7ccce874} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37462) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where d >= '2020-09-01 00:00:00' and d <= '2020-10-01 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:29.258635 [ 17479 ] {f5c48277-6124-438f-9156-6a0a7ccce874} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:29.477179 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:29.586309 [ 3276 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:29.829181 [ 2785 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:30.115611 [ 2796 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:30.557178 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:30.588675 [ 2806 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:30.832901 [ 2799 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:31.124195 [ 2809 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:31.591660 [ 3271 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:31.738022 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:31.835812 [ 2814 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:31.839097 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:32.127549 [ 2787 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:32.594693 [ 2819 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:32.838544 [ 2840 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:32.945514 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:33.029329 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:33.130860 [ 2830 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:33.597908 [ 2856 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:33.842166 [ 2867 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:34.133871 [ 2876 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:34.277488 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:34.653852 [ 2873 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:34.845527 [ 2896 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:35.136947 [ 2889 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:35.486097 [ 17478 ] {913b3a3c-41f4-43a7-9569-39df8d0a3de5} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47594) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where d >= '2020-09-01 00:00:00' and d < '2020-10-01 00:00:00' and a<>3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:35.534816 [ 17478 ] {913b3a3c-41f4-43a7-9569-39df8d0a3de5} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:35.575088 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:35.665887 [ 2892 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:35.848906 [ 2883 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:36.002652 [ 17478 ] {80cafb97-d7dd-4c3f-98d8-3a55c7554448} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47608) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where d >= '2020-09-01 00:00:00' and d < '2020-10-01 00:00:00' and a<>3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:36.021639 [ 17478 ] {80cafb97-d7dd-4c3f-98d8-3a55c7554448} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=11, jobs=11). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:36.140221 [ 2845 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:36.669033 [ 2907 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:36.683465 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:36.853791 [ 2922 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:37.011889 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:37.143708 [ 2912 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:37.672277 [ 2941 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:37.768779 [ 3380 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_132_264_24}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:37.856575 [ 2940 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:37.983463 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:38.098436 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:38.146572 [ 2944 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:38.505868 [ 17478 ] {593e6db5-9bbf-498f-b362-2aa32fca3a44} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47656) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where a = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:38.592574 [ 17478 ] {593e6db5-9bbf-498f-b362-2aa32fca3a44} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:38.676245 [ 2958 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:38.859861 [ 2961 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:39.033001 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:39.155504 [ 2953 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:39.224728 [ 17478 ] {3b208688-4694-4ce0-b340-7c1c544456aa} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47668) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where a = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:42:39.230014 [ 17478 ] {3b208688-4694-4ce0-b340-7c1c544456aa} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=14, jobs=14). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:42:39.678987 [ 2983 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:39.862805 [ 2982 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:40.159127 [ 2985 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:40.257389 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:40.682051 [ 3001 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:40.865850 [ 3007 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:41.162575 [ 3012 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:41.528003 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:41.530197 [ 17478 ] {4a476dbd-89ae-451d-bee5-13c251ddbbc0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47706) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where a <> 66;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:41.553622 [ 17478 ] {4a476dbd-89ae-451d-bee5-13c251ddbbc0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:41.685028 [ 3014 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:41.869145 [ 2998 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:42.113871 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:42.165774 [ 2894 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:42.287422 [ 17478 ] {d3f2712c-dd2b-405c-a4f1-3a6d711c6fe0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47726) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where a <> 66;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:42.302493 [ 17478 ] {d3f2712c-dd2b-405c-a4f1-3a6d711c6fe0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:42.688881 [ 3034 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:42.777009 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:42.872706 [ 3030 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.047492 [ 17478 ] {5910c03d-47fc-484e-b7b3-bfaa036af2a0} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47734) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where a = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:42:43.063037 [ 17478 ] {5910c03d-47fc-484e-b7b3-bfaa036af2a0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0): While executing MergeTreeSelect(pool: ReadPool, algorithm: Thread). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeReadTask.cpp:44: DB::MergeTreeReadTask::createReaders(std::shared_ptr const&, DB::MergeTreeReadTask::Extras const&, DB::MarkRanges const&) @ 0x000000002c83ea0b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:295: DB::MergeTreeReadPoolBase::createTask(std::shared_ptr, DB::MarkRanges, DB::MergeTreeReadTask*) const @ 0x000000002deb7fd4 14. ./build_docker/./src/Storages/MergeTree/MergeTreeReadPool.cpp:146: DB::MergeTreeReadPool::getTask(unsigned long, DB::MergeTreeReadTask*) @ 0x000000002df0d98c 15. ./build_docker/./src/Storages/MergeTree/MergeTreeSelectProcessor.cpp:0: DB::MergeTreeSelectProcessor::read() @ 0x000000002c838672 16. ./build_docker/./src/Storages/MergeTree/MergeTreeSource.cpp:180: DB::MergeTreeSource::tryGenerate() @ 0x000000002de8939a 17. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 18. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 19. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 22. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 23. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 25. asan_thread_start(void*) @ 0x000000000aa47059 26. ? @ 0x00007f7519d19ac3 27. ? @ 0x00007f7519dab850 2025.10.23 23:42:43.183703 [ 3047 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.315861 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.693066 [ 3057 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:43.875544 [ 3062 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:44.172557 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:44.188498 [ 3063 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:44.696346 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:44.878195 [ 3079 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:45.191869 [ 3090 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:45.342604 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:45.701147 [ 3094 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:45.881747 [ 3072 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:46.195017 [ 3100 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:46.573899 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:46.704389 [ 3114 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:46.885748 [ 3117 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:47.197878 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:47.271964 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:47.707485 [ 3131 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:47.807488 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:47.888501 [ 3134 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:48.200739 [ 3142 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:48.503306 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:48.710647 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:48.892397 [ 3145 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:49.022597 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:49.054392 [ 17478 ] {4a745116-069d-4893-9f50-ed9c55657a6d} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54868) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where toStartOfDay(d) >= '2020-10-01 00:00:00';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:49.075995 [ 17478 ] {4a745116-069d-4893-9f50-ed9c55657a6d} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:49.203826 [ 3156 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:49.558562 [ 17478 ] {ce686d49-cfb1-438b-863d-be0ca65575a1} 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.10542.altinitytest (altinity build)) (from [::1]:54888) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where a <> 66;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:42:49.578797 [ 17478 ] {ce686d49-cfb1-438b-863d-be0ca65575a1} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:42:49.713984 [ 3153 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:49.896292 [ 3118 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:50.206725 [ 3175 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:50.279752 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:50.718097 [ 3191 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:50.899212 [ 3202 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:51.279263 [ 3195 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:51.549931 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:51.720467 [ 3208 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:51.902777 [ 3214 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:52.281682 [ 3226 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:52.384335 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:52.636819 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:52.722889 [ 3225 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:52.913418 [ 3233 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:53.254301 [ 17478 ] {f89f2715-de5e-49bc-9ca2-8511b6168019} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54966) (comment: 01508_partition_pruning_long_2.sh) (in query: select uniqExact(_part), count() from xMM where d >= '2020-09-01 00:00:00' and d < '2020-10-01 00:00:00' and a<>3;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:53.259104 [ 17478 ] {f89f2715-de5e-49bc-9ca2-8511b6168019} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:42:53.283499 [ 3238 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:53.604780 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:53.725268 [ 3221 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:53.778773 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:53.917425 [ 3252 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:54.285402 [ 3265 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:54.727843 [ 3267 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:54.891216 [ 18922 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:54.920637 [ 2773 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:55.288274 [ 3261 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:55.300418 [ 17478 ] {6277c12a-3b4e-4bd3-83dc-530b6bda6334} executeQuery: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53766) (comment: 02133_issue_32458.sql) (in query: CREATE TABLE t1 (`id` Int32, `key` String) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:42:55.325906 [ 17478 ] {6277c12a-3b4e-4bd3-83dc-530b6bda6334} TCPHandler: Code: 57. DB::Exception: Table test_13.t1 already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:42:55.730737 [ 2785 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:55.923710 [ 2798 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:56.069518 [ 17478 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:56.290991 [ 2778 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:56.734653 [ 2795 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:56.926668 [ 2782 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.153512 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:57.294196 [ 2821 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.488840 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.737853 [ 3281 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:57.930004 [ 2787 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:58.275599 [ 17479 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:58.297241 [ 2819 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:58.741903 [ 2838 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:58.778903 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:58.933364 [ 2850 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:59.300697 [ 2856 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:59.481874 [ 15589 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:42:59.745615 [ 2851 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:42:59.937149 [ 2876 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:00.303989 [ 2887 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:00.515113 [ 18922 ] {4b1a7535-b374-457a-aff2-6e6f1f5759d1} executeQuery: Code: 60. DB::Exception: Table test_l0hj3sb5.dst does not exist. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58042) (comment: 03008_deduplication_wrong_mv.sql) (in query: DROP DATABASE IF EXISTS test_l0hj3sb5 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:644: DB::StorageMaterializedView::getTargetTable() const @ 0x000000002b940e85 8. ./src/Storages/StorageMaterializedView.h:36: DB::StorageMaterializedView::supportsTransactions() const @ 0x000000002b952070 9. ./build_docker/./src/Interpreters/IInterpreter.cpp:39: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029195794 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd661 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 17. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 18. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 24. asan_thread_start(void*) @ 0x000000000aa47059 25. ? @ 0x00007f7519d19ac3 26. ? @ 0x00007f7519dab850 2025.10.23 23:43:00.520987 [ 18922 ] {4b1a7535-b374-457a-aff2-6e6f1f5759d1} DynamicQueryHandler: Code: 60. DB::Exception: Table test_l0hj3sb5.dst does not exist. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Databases/IDatabase.cpp:37: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc47e 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Storages/StorageMaterializedView.cpp:644: DB::StorageMaterializedView::getTargetTable() const @ 0x000000002b940e85 8. ./src/Storages/StorageMaterializedView.h:36: DB::StorageMaterializedView::supportsTransactions() const @ 0x000000002b952070 9. ./build_docker/./src/Interpreters/IInterpreter.cpp:39: DB::IInterpreter::checkStorageSupportsTransactionsIfNeeded(std::shared_ptr const&, std::shared_ptr, bool) @ 0x0000000029195794 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fd661 11. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 12. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 13. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 14. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 17. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 18. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 19. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 24. asan_thread_start(void*) @ 0x000000000aa47059 25. ? @ 0x00007f7519d19ac3 26. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:00.748675 [ 2893 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:01.007816 [ 2889 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:01.306671 [ 2908 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:01.377260 [ 18922 ] {434661fb-9bdc-404d-8090-7afd4bce87ff} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53888) (comment: 02183_dictionary_date_types.sql) (in query: CREATE TABLE 02183_dictionary_source_table ( id UInt64, value_date Date, value_date_32 Date32, value_date_time DateTime, value_date_time_64 DateTime64 ) ENGINE=TinyLog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:01.386412 [ 18922 ] {434661fb-9bdc-404d-8090-7afd4bce87ff} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:01.752844 [ 2901 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:01.986562 [ 3391 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {c58953eb-e53f-49f0-8b54-9d4308b6cc29::202510_1_87_21}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:02.009966 [ 2927 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:02.239383 [ 18922 ] {63ff58dd-db40-41e8-afe4-998854b020bd} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53926) (comment: 00930_max_partitions_per_insert_block.sql) (in query: CREATE TABLE partitions (`x` UInt64) ENGINE = MergeTree PARTITION BY x ORDER BY x SETTINGS index_granularity = 29610, min_bytes_for_wide_part = 971413164, ratio_of_defaults_for_sparse_serialization = 0.05398713797330856, 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 = 486301206, compact_parts_max_granules_to_buffer = 256, compact_parts_merge_max_bytes_to_prefetch_part = 30801102, merge_max_block_size = 5191, 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 = 10074481283, index_granularity_bytes = 2469954, concurrent_part_removal_threshold = 59, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 33000, primary_key_compress_block_size = 81255), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:02.242292 [ 18922 ] {63ff58dd-db40-41e8-afe4-998854b020bd} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:02.310112 [ 2938 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:02.698566 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:02.764632 [ 2940 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:03.064712 [ 2944 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:03.130287 [ 15589 ] {785ac66c-dd5b-4bc7-a4f8-854418401f91} DatabaseReplicated (test_11): It's not recommended to explicitly specify zookeeper_path and replica_name in ReplicatedMergeTree arguments 2025.10.23 23:43:03.135810 [ 15589 ] {785ac66c-dd5b-4bc7-a4f8-854418401f91} 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.10542.altinitytest (altinity build)) (from [::1]:53934) (comment: 01079_alter_default_zookeeper_long.sql) (in query: CREATE TABLE alter_default ( date Date, key UInt64 ) ENGINE ReplicatedMergeTree('/clickhouse/tables/{database}/test_01079/alter_default', '1') ORDER BY key;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:878: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000027d65967 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d68cd6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d69a7e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:43:03.138458 [ 15589 ] {785ac66c-dd5b-4bc7-a4f8-854418401f91} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:878: DB::DatabaseReplicated::checkTableEngine(DB::ASTCreateQuery const&, DB::ASTStorage&, std::shared_ptr) const @ 0x0000000027d65967 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:957: DB::DatabaseReplicated::checkQueryValid(std::shared_ptr const&, std::shared_ptr) const @ 0x0000000027d68cd6 6. ./build_docker/./src/Databases/DatabaseReplicated.cpp:999: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d69a7e 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:43:03.313107 [ 2958 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:03.764953 [ 18099 ] {889e6ba9-af9b-47df-858a-67b1c4375c2a} executeQuery: Code: 344. DB::Exception: Deduplication in dependent materialized view cannot work together with async inserts. Please disable either `deduplicate_blocks_in_dependent_materialized_views` or `async_insert` setting. (SUPPORT_IS_DISABLED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53942) (comment: 03006_mv_deduplication_throw_if_async_insert.sql) (in query: INSERT INTO 03006_test VALUES ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1062: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b47b0a 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:43:03.770672 [ 18099 ] {889e6ba9-af9b-47df-858a-67b1c4375c2a} TCPHandler: Code: 344. DB::Exception: Deduplication in dependent materialized view cannot work together with async inserts. Please disable either `deduplicate_blocks_in_dependent_materialized_views` or `async_insert` setting. (SUPPORT_IS_DISABLED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/executeQuery.cpp:1062: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b47b0a 5. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 7. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 8. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 10. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 11. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:43:03.772118 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:03.787268 [ 18099 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_analyzer should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:43:03.927511 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:04.067366 [ 2982 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:04.316054 [ 2991 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:04.775192 [ 2996 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:05.069969 [ 3012 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:05.319280 [ 3027 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:05.778356 [ 3017 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:06.025223 [ 15589 ] {b7fca047-cf79-48be-bf91-fd98088fd720} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59914) (comment: 01095_tpch_like_smoke.sql) (in query: CREATE TABLE part (`p_partkey` Int32, `p_name` String, `p_mfgr` FixedString(25), `p_brand` FixedString(10), `p_type` String, `p_size` Int32, `p_container` FixedString(10), `p_retailprice` Decimal(18, 2), `p_comment` String, CONSTRAINT pk CHECK p_partkey >= 0, CONSTRAINT positive CHECK (p_size >= 0) AND (p_retailprice >= 0)) ENGINE = MergeTree ORDER BY p_partkey SETTINGS index_granularity = 14325, min_bytes_for_wide_part = 439755760, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 57, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 139534224, compact_parts_max_granules_to_buffer = 168, compact_parts_merge_max_bytes_to_prefetch_part = 13172893, merge_max_block_size = 2540, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 764398015, 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 = 15666317, concurrent_part_removal_threshold = 59, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 68200, primary_key_compress_block_size = 71134), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:06.029691 [ 15589 ] {b7fca047-cf79-48be-bf91-fd98088fd720} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:06.072601 [ 3037 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:06.322411 [ 3041 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:06.781037 [ 3023 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:07.075690 [ 3042 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:07.313855 [ 18099 ] {e6591c9e-e1a1-4870-94a9-e26d1318c5e7} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59934) (comment: 00330_view_subqueries.sql) (in query: CREATE VIEW v1 AS SELECT 1 FROM (SELECT 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:07.329381 [ 3011 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:07.334814 [ 18099 ] {e6591c9e-e1a1-4870-94a9-e26d1318c5e7} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:07.783722 [ 3059 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:07.843924 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.078902 [ 3075 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.332491 [ 3074 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:08.787041 [ 3078 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.069957 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.081674 [ 3093 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.155239 [ 15589 ] {66833b82-1ab2-4708-95db-2319a52816ae} executeQuery: Code: 57. DB::Exception: Table test_13.test_log already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59942) (comment: 02771_log_faminy_truncate_count.sql) (in query: CREATE TABLE test_log ( `crypto_name` String, `trade_date` Date ) ENGINE = StripeLog;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:43:09.161929 [ 15589 ] {66833b82-1ab2-4708-95db-2319a52816ae} TCPHandler: Code: 57. DB::Exception: Table test_13.test_log already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:43:09.336573 [ 3104 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:09.792911 [ 3114 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.084539 [ 3120 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.176876 [ 15589 ] {2ed43cad-4e47-467d-8bc1-1c35339a59c3} executeQuery: Code: 70. DB::Exception: Cannot convert infinite value to integer type. (CANNOT_CONVERT_TYPE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59956) (comment: 01557_field_infinite_convert_to_number.sql) (in query: SET max_threads = nan;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Core/SettingsFields.cpp:88: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x000000002774b225 5. ./build_docker/./src/Core/SettingsFields.cpp:223: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x000000002774f8db 6. ./src/Core/Field.h:707: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda31'(DB::Field const&)::__invoke(DB::Field const&) @ 0x0000000027384e97 7. ./src/Core/Settings.h:1319: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x0000000026f88271 8. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f85256 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f857c3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002854616d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000029502a1b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:43:10.187369 [ 15589 ] {2ed43cad-4e47-467d-8bc1-1c35339a59c3} TCPHandler: Code: 70. DB::Exception: Cannot convert infinite value to integer type. (CANNOT_CONVERT_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Core/SettingsFields.cpp:88: unsigned long DB::(anonymous namespace)::fieldToNumber(DB::Field const&) @ 0x000000002774b225 5. ./build_docker/./src/Core/SettingsFields.cpp:223: DB::SettingFieldMaxThreads::SettingFieldMaxThreads(DB::Field const&) @ 0x000000002774f8db 6. ./src/Core/Field.h:707: DB::SettingsTraits::Accessor::instance()::$_0::operator()() const::'lambda31'(DB::Field const&)::__invoke(DB::Field const&) @ 0x0000000027384e97 7. ./src/Core/Settings.h:1319: bool DB::getNewValueToCheck(DB::Settings const&, DB::SettingChange&, DB::Field&, bool) @ 0x0000000026f88271 8. ./build_docker/./src/Access/SettingsConstraints.cpp:285: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f85256 9. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges const&, DB::SettingSource) const @ 0x0000000026f857c3 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraints(DB::SettingsChanges const&, DB::SettingSource) @ 0x000000002854616d 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterSetQuery::execute() @ 0x0000000029502a1b 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:43:10.337772 [ 18099 ] {c04621ea-adf0-41cc-8c32-987c190619d0} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59970) (comment: 00825_protobuf_format_table_default.sh) (in query: CREATE TABLE table_default_protobuf_00825 (`x` Int64, `y` Int64 DEFAULT x * x, `z` Int64 DEFAULT (x * x) * x) ENGINE = MergeTree ORDER BY tuple() SETTINGS index_granularity = 51430, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0.7588199973106384, 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 = 374944963, compact_parts_max_granules_to_buffer = 92, compact_parts_merge_max_bytes_to_prefetch_part = 7292204, merge_max_block_size = 13292, old_parts_lifetime = 480., prefer_fetch_merged_part_size_threshold = 2962622235, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 8449267852, index_granularity_bytes = 16920081, concurrent_part_removal_threshold = 80, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 92750, primary_key_compress_block_size = 99450), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:10.341795 [ 18099 ] {c04621ea-adf0-41cc-8c32-987c190619d0} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:10.346635 [ 3119 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:10.796687 [ 3128 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.087669 [ 3154 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.244735 [ 18099 ] {8af0d6d2-ab72-4b68-a203-c41374247ebe} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59982) (comment: 02366_direct_dictionary_dict_has.sql) (in query: CREATE TABLE test_table ( id UInt64, value String ) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:11.269011 [ 18099 ] {8af0d6d2-ab72-4b68-a203-c41374247ebe} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:11.349378 [ 3163 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:11.799622 [ 3164 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.090906 [ 3185 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.199793 [ 18922 ] {e49f98de-be8c-45a2-8c92-5697719df46f} executeQuery: Code: 36. DB::Exception: Bad HDFS URL: . It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59986) (comment: 01030_storage_hdfs_syntax.sql) (in query: create table test_table_hdfs_syntax (id UInt32) ENGINE = HDFS('') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000026884d3d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002688442f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000267c23d0 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: DB::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000002c1b6a83 8. ./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&) @ 0x000000002c1b80de 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:43:12.216865 [ 18922 ] {e49f98de-be8c-45a2-8c92-5697719df46f} TCPHandler: Code: 36. DB::Exception: Bad HDFS URL: . It should have the following structure 'hdfs://:/path'. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:147: DB::StorageHDFSConfiguration::setURL(String const&) @ 0x0000000026884d3d 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002688442f 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000267c23d0 7. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: DB::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000002c1b6a83 8. ./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&) @ 0x000000002c1b80de 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:43:12.351574 [ 3174 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.375958 [ 18922 ] {2a1644e4-d97a-4ac5-9fce-9cb05cabc8f5} executeQuery: Code: 42. DB::Exception: Storage HDFS requires 1 to 3 arguments. All supported signatures: - uri - uri, format - uri, format, compression_method . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59986) (comment: 01030_storage_hdfs_syntax.sql) (in query: create table test_table_hdfs_syntax (id UInt32) ENGINE = HDFS('','','', '') ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x000000001619595a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:88: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002688469b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000267c23d0 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: DB::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000002c1b6a83 7. ./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&) @ 0x000000002c1b80de 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:43:12.378593 [ 18922 ] {2a1644e4-d97a-4ac5-9fce-9cb05cabc8f5} TCPHandler: Code: 42. DB::Exception: Storage HDFS requires 1 to 3 arguments. All supported signatures: - uri - uri, format - uri, format, compression_method . (NUMBER_OF_ARGUMENTS_DOESNT_MATCH), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&&, String&&) @ 0x000000001619595a 4. ./build_docker/./src/Storages/ObjectStorage/HDFS/Configuration.cpp:88: DB::StorageHDFSConfiguration::fromAST(absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x000000002688469b 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageObjectStorage::Configuration::initialize(DB::StorageObjectStorage::Configuration&, absl::InlinedVector, 7ul, std::allocator>>&, std::shared_ptr, bool) @ 0x00000000267c23d0 6. ./build_docker/./src/Storages/ObjectStorage/registerStorageObjectStorage.cpp:0: DB::createStorageObjectStorage(DB::StorageFactory::Arguments const&, std::shared_ptr, std::shared_ptr) @ 0x000000002c1b6a83 7. ./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&) @ 0x000000002c1b80de 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:43:12.521461 [ 18099 ] {9c74a650-99f5-4577-9fae-fe28b846fa61} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59998) (comment: 02149_read_in_order_fixed_prefix.sql) (in query: CREATE TABLE t_read_in_order (`date` Date, `i` UInt64, `v` UInt64) ENGINE = MergeTree ORDER BY (date, i) SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = false, max_file_name_length = 0, min_bytes_for_full_part_storage = 447497984, compact_parts_max_bytes_to_buffer = 222544527, compact_parts_max_granules_to_buffer = 47, compact_parts_merge_max_bytes_to_prefetch_part = 25399116, merge_max_block_size = 14338, 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 = 7447867580, concurrent_part_removal_threshold = 8, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 63113, primary_key_compress_block_size = 67463), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:12.543103 [ 18099 ] {9c74a650-99f5-4577-9fae-fe28b846fa61} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:12.801984 [ 3193 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:12.975070 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.094076 [ 3197 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.355249 [ 3198 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:13.805182 [ 3211 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.097419 [ 3190 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.249771 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.358597 [ 3222 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:14.810439 [ 3239 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.100244 [ 3155 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.364716 [ 3232 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:15.812896 [ 3252 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.103244 [ 3247 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.367445 [ 3243 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:16.815563 [ 2774 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.106646 [ 3270 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.369853 [ 2779 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.512147 [ 18922 ] {c0e2080e-0a39-4f92-9135-4a2f695a4e89} executeQuery: Code: 43. DB::Exception: Illegal argument of type DateTime for function toStartOfInterval: In scope SELECT dateTrunc('Nanosecond', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49894) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('Nanosecond', toDateTime('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateTimeIsNotSupported(char const*) @ 0x000000000aaab433 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cad8e 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c919a 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:17.516940 [ 18922 ] {c0e2080e-0a39-4f92-9135-4a2f695a4e89} TCPHandler: Code: 43. DB::Exception: Illegal argument of type DateTime for function toStartOfInterval: In scope SELECT dateTrunc('Nanosecond', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateTimeIsNotSupported(char const*) @ 0x000000000aaab433 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cad8e 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c919a 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:17.818406 [ 2798 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:17.834705 [ 18922 ] {af5c28b5-4d52-485d-adc7-cf52d70e8964} executeQuery: Code: 43. DB::Exception: Illegal argument of type DateTime for function toStartOfInterval: In scope SELECT dateTrunc('MicroSecond', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49894) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('MicroSecond', toDateTime('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateTimeIsNotSupported(char const*) @ 0x000000000aaab433 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cad9f 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c919a 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:17.838533 [ 18922 ] {af5c28b5-4d52-485d-adc7-cf52d70e8964} TCPHandler: Code: 43. DB::Exception: Illegal argument of type DateTime for function toStartOfInterval: In scope SELECT dateTrunc('MicroSecond', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateTimeIsNotSupported(char const*) @ 0x000000000aaab433 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cad9f 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c919a 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.062873 [ 18922 ] {ec75d4e0-dcba-4fc8-b6b8-e66d8b382436} executeQuery: Code: 43. DB::Exception: Illegal argument of type DateTime for function toStartOfInterval: In scope SELECT dateTrunc('MILLISECOND', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49894) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('MILLISECOND', toDateTime('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateTimeIsNotSupported(char const*) @ 0x000000000aaab433 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cad7d 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c919a 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.066550 [ 18922 ] {ec75d4e0-dcba-4fc8-b6b8-e66d8b382436} TCPHandler: Code: 43. DB::Exception: Illegal argument of type DateTime for function toStartOfInterval: In scope SELECT dateTrunc('MILLISECOND', toDateTime('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateTimeIsNotSupported(char const*) @ 0x000000000aaab433 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDateTime const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cad7d 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c919a 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.078222 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.109124 [ 2786 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.232786 [ 18922 ] {08f9d3eb-d03f-42b2-9c42-2aabb5315b38} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfInterval: In scope SELECT dateTrunc('Nanosecond', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49894) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('Nanosecond', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateIsNotSupported(char const*) @ 0x000000000aaab2b3 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cc4c9 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c91da 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.236194 [ 18922 ] {08f9d3eb-d03f-42b2-9c42-2aabb5315b38} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfInterval: In scope SELECT dateTrunc('Nanosecond', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateIsNotSupported(char const*) @ 0x000000000aaab2b3 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cc4c9 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c91da 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.372472 [ 2789 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:18.580956 [ 18922 ] {19b9a579-f558-4e33-91af-ff074060ed09} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfInterval: In scope SELECT dateTrunc('MicroSecond', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49894) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('MicroSecond', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateIsNotSupported(char const*) @ 0x000000000aaab2b3 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cc4eb 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c91da 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.593501 [ 18922 ] {19b9a579-f558-4e33-91af-ff074060ed09} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfInterval: In scope SELECT dateTrunc('MicroSecond', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateIsNotSupported(char const*) @ 0x000000000aaab2b3 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cc4eb 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c91da 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.797549 [ 18922 ] {9b359357-12ac-4191-b07a-d1c1fb1694e0} executeQuery: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfInterval: In scope SELECT dateTrunc('MILLISECOND', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49894) (comment: 02935_date_trunc_case_unsensitiveness.sql) (in query: SELECT dateTrunc('MILLISECOND', toDate('2022-03-01'));), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateIsNotSupported(char const*) @ 0x000000000aaab2b3 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cc4b8 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c91da 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.800249 [ 18922 ] {9b359357-12ac-4191-b07a-d1c1fb1694e0} TCPHandler: Code: 43. DB::Exception: Illegal argument of type Date for function toStartOfInterval: In scope SELECT dateTrunc('MILLISECOND', toDate('2022-03-01')). (ILLEGAL_TYPE_OF_ARGUMENT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, char const*&) @ 0x000000000aaab574 4. DB::throwDateIsNotSupported(char const*) @ 0x000000000aaab2b3 5. COW::immutable_ptr DB::FunctionToStartOfInterval::dispatchForIntervalColumn>(DB::DataTypeDate const&, DB::ColumnVector const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long, unsigned short) const @ 0x00000000186cc4b8 6. DB::FunctionToStartOfInterval::dispatchForTimeColumn(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&, std::shared_ptr const&, DateLUTImpl const&, unsigned long) const @ 0x00000000186c91da 7. DB::FunctionToStartOfInterval::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000186c80c0 8. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 13. DB::(anonymous namespace)::FunctionDateTrunc::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000e9e22a1 14. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 15. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 16. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 17. DB::IExecutableFunction::defaultImplementationForConstantArguments(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd01ab 18. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0c2a 19. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 20. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 21. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 22. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 23. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 24. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 25. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 26. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 27. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 28. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 29. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 30. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 31. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 2025.10.23 23:43:18.821566 [ 2805 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.111494 [ 2801 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.359350 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.375251 [ 2807 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.826985 [ 3281 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:19.904155 [ 3384 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7375513c-4863-4bde-85c7-c66f94b39dbd::202510_1_131_26}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.114680 [ 2825 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.219060 [ 18099 ] {86037afb-ec47-4a35-bf6d-99d1fdeaebf4} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:60014) (comment: 03165_round_scale_as_column.sql) (in query: CREATE TABLE tab ( id Int32, scale Int16, u8 UInt8, u16 UInt16, u32 UInt32, u64 UInt64, i8 Int8, i16 Int16, i32 Int32, i64 Int64, f32 Float32, f64 Float64 ) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:20.221558 [ 18099 ] {86037afb-ec47-4a35-bf6d-99d1fdeaebf4} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:20.377906 [ 2835 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:20.887501 [ 2839 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.117570 [ 2858 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.128900 [ 18099 ] {1ac09c1b-ca5a-435b-9e56-7d17ae3d2100} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49914) (comment: 01305_nullable-prewhere_bug.sql) (in query: CREATE TABLE data (`ts` DateTime, `field` String, `num_field` Nullable(Float64)) ENGINE = MergeTree PARTITION BY ts ORDER BY ts SETTINGS index_granularity = 42894, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 44, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 121388238, compact_parts_max_granules_to_buffer = 119, compact_parts_merge_max_bytes_to_prefetch_part = 21835782, merge_max_block_size = 18595, old_parts_lifetime = 286., 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 = 10674879637, index_granularity_bytes = 1054639, concurrent_part_removal_threshold = 3, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 19734, primary_key_compress_block_size = 72842), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:21.132081 [ 18099 ] {1ac09c1b-ca5a-435b-9e56-7d17ae3d2100} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:21.380670 [ 2870 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:21.890299 [ 2875 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.064198 [ 18099 ] {a5bbb814-2cb5-451e-8489-10bc22775286} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49920) (comment: 01414_push_predicate_when_contains_with_clause.sql) (in query: CREATE TABLE numbers_indexed ENGINE = MergeTree PARTITION BY bitShiftRight(number, 8) ORDER BY number SETTINGS index_granularity = 8, min_bytes_for_wide_part = 343170262, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 83, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 505621003, compact_parts_max_granules_to_buffer = 235, compact_parts_merge_max_bytes_to_prefetch_part = 7521994, merge_max_block_size = 10736, 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 = 1, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 5981472, concurrent_part_removal_threshold = 95, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = true, marks_compress_block_size = 52441, primary_key_compress_block_size = 44294 AS SELECT * FROM numbers(16384)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:22.067390 [ 18099 ] {a5bbb814-2cb5-451e-8489-10bc22775286} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:22.143708 [ 2881 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.384198 [ 2884 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.774404 [ 18922 ] {559de1e6-e641-44ea-bb2e-c184594f8430} executeQuery: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable('', '', ''). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49904) (comment: 00386_has_column_in_table.sql) (in query: /* bad queries */ SELECT hasColumnInTable('', '', '');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abcce8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:43:22.777247 [ 18922 ] {559de1e6-e641-44ea-bb2e-c184594f8430} TCPHandler: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable('', '', ''). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abcce8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:43:22.902778 [ 2891 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:22.979604 [ 18922 ] {8f17826e-de8f-4d05-ac95-ab62f74dc0ea} executeQuery: Code: 81. DB::Exception: Empty database name: In scope SELECT hasColumnInTable('', 't', 'c'). (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49904) (comment: 00386_has_column_in_table.sql) (in query: SELECT hasColumnInTable('', 't', 'c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b97b9 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 5. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abbc39 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:43:22.986202 [ 18922 ] {8f17826e-de8f-4d05-ac95-ab62f74dc0ea} TCPHandler: Code: 81. DB::Exception: Empty database name: In scope SELECT hasColumnInTable('', 't', 'c'). (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b97b9 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 5. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abbc39 6. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 7. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 8. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 9. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 10. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 11. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 18. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 21. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 22. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:43:23.075911 [ 18922 ] {08d5aeb5-a171-4ac2-97e7-4b1fd30e92f7} executeQuery: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable(currentDatabase(), '', 'c'). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49904) (comment: 00386_has_column_in_table.sql) (in query: SELECT hasColumnInTable(currentDatabase(), '', 'c');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abcce8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:43:23.078652 [ 18922 ] {08d5aeb5-a171-4ac2-97e7-4b1fd30e92f7} TCPHandler: Code: 60. DB::Exception: Table name is empty: In scope SELECT hasColumnInTable(currentDatabase(), '', 'c'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abcce8 5. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 6. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 17. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 18. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 20. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 21. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 23. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 24. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 25. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 26. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 27. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 28. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 29. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 30. asan_thread_start(void*) @ 0x000000000aa47059 31. ? @ 0x00007f7519d19ac3 2025.10.23 23:43:23.147009 [ 2897 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.217009 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.303660 [ 18922 ] {f17f2a94-7835-4065-a076-14449d280951} executeQuery: Code: 81. DB::Exception: Database d does not exist: In scope SELECT hasColumnInTable('d', 't', 's'). (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49904) (comment: 00386_has_column_in_table.sql) (in query: SELECT hasColumnInTable('d', 't', 's');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:418: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286badea 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 6. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abbc39 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:43:23.313143 [ 18922 ] {f17f2a94-7835-4065-a076-14449d280951} TCPHandler: Code: 81. DB::Exception: Database d does not exist: In scope SELECT hasColumnInTable('d', 't', 's'). (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:418: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286badea 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 6. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abbc39 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 19. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 20. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 22. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 23. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 24. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 25. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 26. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 27. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 28. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 29. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 30. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 31. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 2025.10.23 23:43:23.469182 [ 2892 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.498991 [ 18922 ] {7ed6b926-2b8d-473c-b6a3-ad2702c5f25d} executeQuery: Code: 60. DB::Exception: Table test_13.t does not exist. Maybe you meant test_13.s?: In scope SELECT hasColumnInTable(currentDatabase(), 't', 's'). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49904) (comment: 00386_has_column_in_table.sql) (in query: SELECT hasColumnInTable(currentDatabase(), 't', 's');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abbc39 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 2025.10.23 23:43:23.504121 [ 18922 ] {7ed6b926-2b8d-473c-b6a3-ad2702c5f25d} TCPHandler: Code: 60. DB::Exception: Table test_13.t does not exist. Maybe you meant test_13.s?: In scope SELECT hasColumnInTable(currentDatabase(), 't', 's'). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. DB::(anonymous namespace)::FunctionHasColumnInTable::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x0000000011abbc39 8. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 9. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 10. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 11. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 12. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 13. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 20. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 21. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 23. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 24. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 26. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 28. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 29. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 30. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 31. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 2025.10.23 23:43:23.902233 [ 18099 ] {ebb93e63-e8e3-438b-a98e-82d3b6283e1d} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:49932) (comment: 03032_redundant_equals.sql) (in query: CREATE TABLE test_table (`k` UInt64) ENGINE = MergeTree ORDER BY k SETTINGS index_granularity = 8192, index_granularity_bytes = '10Mi', min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 0, compact_parts_max_bytes_to_buffer = 489178198, compact_parts_max_granules_to_buffer = 3, compact_parts_merge_max_bytes_to_prefetch_part = 19693481, merge_max_block_size = 6549, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 6310075097, vertical_merge_algorithm_min_rows_to_activate = 1, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 10737418240, concurrent_part_removal_threshold = 59, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 70402, primary_key_compress_block_size = 32593), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:23.905359 [ 2845 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:23.919558 [ 18099 ] {ebb93e63-e8e3-438b-a98e-82d3b6283e1d} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:24.149838 [ 2918 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.472387 [ 2927 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.493284 [ 18922 ] {8bad605b-9d40-4322-a16d-4f1073450dbb} executeQuery: Code: 397. DB::Exception: UNION is not supported for MATERIALIZED VIEW. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41280) (comment: 03247_materialized_view_select_intersect.sql) (in query: CREATE MATERIALIZED VIEW v0 AS (SELECT 1) INTERSECT (SELECT 1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/SelectQueryDescription.cpp:133: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000002b714737 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x000000002b93c7c8 6. ./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&) @ 0x000000002b952d90 7. ./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&) @ 0x000000002b950a2c 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:43:24.502611 [ 18922 ] {8bad605b-9d40-4322-a16d-4f1073450dbb} TCPHandler: Code: 397. DB::Exception: UNION is not supported for MATERIALIZED VIEW. (QUERY_IS_NOT_SUPPORTED_IN_MATERIALIZED_VIEW), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Storages/SelectQueryDescription.cpp:133: DB::SelectQueryDescription::getSelectQueryFromASTForMatView(std::shared_ptr const&, bool, std::shared_ptr) @ 0x000000002b714737 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::StorageMaterializedView::StorageMaterializedView(DB::StorageID const&, std::shared_ptr, DB::ASTCreateQuery const&, DB::ColumnsDescription const&, DB::LoadingStrictnessLevel, String const&) @ 0x000000002b93c7c8 6. ./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&) @ 0x000000002b952d90 7. ./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&) @ 0x000000002b950a2c 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:43:24.518975 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:24.908219 [ 2938 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:25.075926 [ 18922 ] {b312c543-e8fb-48f1-8b54-0ff9f4601ab5} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41286) (comment: 01254_array_of_unnamed_tuples.sql) (in query: CREATE TABLE mass_table_457 (key Array(Tuple(Float64, Float64)), name String, value UInt64) ENGINE = Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:25.080192 [ 18922 ] {b312c543-e8fb-48f1-8b54-0ff9f4601ab5} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:25.152479 [ 2930 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:25.475435 [ 2946 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:25.910945 [ 2960 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.155199 [ 2961 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.479164 [ 2968 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:26.915732 [ 2984 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.158791 [ 2992 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.483175 [ 3000 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:27.918612 [ 3039 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.162223 [ 2997 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.168229 [ 15589 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.307714 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.486588 [ 3051 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:28.935604 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.164975 [ 3091 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.489840 [ 3096 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.615782 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:29.939371 [ 3111 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.167459 [ 3121 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.493375 [ 3124 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:30.942489 [ 3107 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.170360 [ 3161 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.498644 [ 3159 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:31.945942 [ 3184 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.173140 [ 3181 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.502404 [ 3175 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:32.949866 [ 3157 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.176254 [ 3195 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.505331 [ 3216 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.512379 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:33.953227 [ 3230 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.263023 [ 3235 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.508576 [ 3221 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.666645 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:34.956407 [ 3279 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.266009 [ 2779 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.512209 [ 2772 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:35.963831 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.276702 [ 2797 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.515861 [ 2807 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:36.619721 [ 18099 ] {586d5066-29d2-47eb-b668-51f68860c393} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41288) (comment: 00910_zookeeper_custom_compression_codecs_replicated_long.sql) (in query: SELECT floor(sum(somenum), 1) FROM compression_codec_multiple_replicated1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:43:36.631103 [ 18099 ] {586d5066-29d2-47eb-b668-51f68860c393} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:43:36.967328 [ 2787 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:37.279745 [ 2837 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:37.519180 [ 2834 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:37.970314 [ 2842 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.216365 [ 15589 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.283100 [ 2856 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.555702 [ 2846 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.661878 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:38.973324 [ 2874 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.286435 [ 2861 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.558885 [ 2890 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.850148 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:39.976337 [ 2903 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.289520 [ 2914 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.562727 [ 2907 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:40.985863 [ 2924 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.296872 [ 2912 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.566117 [ 2940 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:41.989826 [ 2944 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.299957 [ 2955 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.615611 [ 2953 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:42.991781 [ 18922 ] {abcc754f-53c2-46ce-829e-c62c5befd49d} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40138) (comment: 02833_window_func_range_offset.sql) (in query: -- invalid start offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN 0.0 PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000029a730c0 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000029a723be 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9c66 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3171: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fc6b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:42.995127 [ 18922 ] {abcc754f-53c2-46ce-829e-c62c5befd49d} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000029a730c0 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000029a723be 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9c66 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3171: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fc6b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:42.995464 [ 2986 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.066253 [ 18922 ] {37b9a1bd-5fd4-4434-94cf-0a128de4f27b} executeQuery: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40138) (comment: 02833_window_func_range_offset.sql) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN nan PRECEDING AND UNBOUNDED FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000029a730c0 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000029a723be 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9c66 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3171: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fc6b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:43.068271 [ 18922 ] {37b9a1bd-5fd4-4434-94cf-0a128de4f27b} TCPHandler: Code: 36. DB::Exception: Frame start offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000029a730c0 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:100: DB::WindowFrame::checkValid() const @ 0x0000000029a723be 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9c66 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3171: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fc6b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:43.135694 [ 18922 ] {2a064210-2cb5-4d06-b518-6bf6815625b7} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40138) (comment: 02833_window_func_range_offset.sql) (in query: -- invalid end offset with RANGE SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND 0.0 FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000029a730c0 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000029a724d0 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9c66 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3171: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fc6b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:43.138217 [ 18922 ] {2a064210-2cb5-4d06-b518-6bf6815625b7} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, '0.' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000029a730c0 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000029a724d0 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9c66 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3171: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fc6b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:43.168317 [ 18922 ] {de24515e-d73a-45da-a828-12a71720635f} executeQuery: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:40138) (comment: 02833_window_func_range_offset.sql) (in query: SELECT count() OVER (ORDER BY 3.4028234663852886e38 RANGE BETWEEN UNBOUNDED PRECEDING AND nan FOLLOWING);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000029a730c0 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000029a724d0 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9c66 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3171: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fc6b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:43.170709 [ 18922 ] {de24515e-d73a-45da-a828-12a71720635f} TCPHandler: Code: 36. DB::Exception: Frame end offset for 'RANGE' frame must be a nonnegative 32-bit integer, 'nan' of type 'Float64' given. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, DB::WindowFrame::FrameType const&, String&&, DB::Field::Types::Which&&) @ 0x0000000029a730c0 4. ./build_docker/./src/Interpreters/WindowDescription.cpp:113: DB::WindowFrame::checkValid() const @ 0x0000000029a724d0 5. ./contrib/llvm-project/libcxx/include/string:1499: DB::QueryAnalyzer::resolveWindow(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283b9c66 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3171: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x000000002839fc6b 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 9. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 13. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 15. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 16. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 17. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 19. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 21. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 22. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 23. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 24. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 25. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:43.303284 [ 2985 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.618463 [ 2971 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.745859 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:43.998914 [ 2951 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.307801 [ 3016 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.622069 [ 3024 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:44.972228 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.002597 [ 3037 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.335096 [ 3038 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.625631 [ 3056 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:45.988540 [ 17481 ] {9a7867c8-50c0-443c-9524-14657ac1b158} executeQuery: Code: 341. DB::Exception: Timeout: Cannot enqueue query on this replica, most likely because replica is busy with previous queue entries. (UNFINISHED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38580) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1_repl_01111_8.rmt_9884_7910_20418 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:322: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db61a8 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:45.991970 [ 17481 ] {9a7867c8-50c0-443c-9524-14657ac1b158} TCPHandler: Code: 341. DB::Exception: Timeout: Cannot enqueue query on this replica, most likely because replica is busy with previous queue entries. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:322: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db61a8 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:43:46.006326 [ 3057 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.298389 [ 4049 ] {1bc5aa13-8d36-4e54-950a-96e9449c5ce0} executeQuery: Code: 47. DB::Exception: Missing columns: 'n' while processing query: 'SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')', required columns: 'n': While processing (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2: While processing n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2): While processing _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'): While processing if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'), n): While processing _CAST(if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'), n), 'Int32'). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from 0.0.0.0:0) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: /* ddl_entry=query-0000000018 */ ALTER TABLE test_1_repl_01111_14.rmt_15100_11738_19605 UPDATE n = n + (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) WHERE 1 SETTINGS allow_nondeterministic_mutations = 1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000299b56b6 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:649: 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 @ 0x0000000029395dfb 6. ./build_docker/./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) @ 0x000000002938c51e 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:212: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029386230 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:259: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000294f05b8 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000294ecbff 10. ./contrib/llvm-project/libcxx/include/vector:432: DB::getQueryInterpreter(DB::ASTSubquery const&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e655e 11. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:0: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295dec84 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295de6bd 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 16. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 17. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 20. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 21. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 22. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 23. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 24. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x00000000299bbc53 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1507: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299bebf9 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b8a22 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2162 31. ./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) @ 0x00000000295a6166 2025.10.23 23:43:46.337814 [ 3051 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:46.413976 [ 4049 ] {1bc5aa13-8d36-4e54-950a-96e9449c5ce0} executeQuery: Code: 47. DB::Exception: Missing columns: 'n' while processing query: 'SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')', required columns: 'n': While processing (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2: While processing n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2): While processing _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'): While processing if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'), n): While processing _CAST(if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'), n), 'Int32'). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:38678) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1_repl_01111_14.rmt_15100_11738_19605 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000299b56b6 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:649: 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 @ 0x0000000029395dfb 6. ./build_docker/./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) @ 0x000000002938c51e 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:212: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029386230 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:259: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000294f05b8 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000294ecbff 10. ./contrib/llvm-project/libcxx/include/vector:432: DB::getQueryInterpreter(DB::ASTSubquery const&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e655e 11. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:0: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295dec84 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295de6bd 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 16. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 17. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 20. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 21. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 22. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 23. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 24. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x00000000299bbc53 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1507: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299bebf9 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b8a22 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2162 31. ./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) @ 0x00000000295a6166 2025.10.23 23:43:46.435510 [ 4049 ] {1bc5aa13-8d36-4e54-950a-96e9449c5ce0} TCPHandler: Code: 47. DB::Exception: Missing columns: 'n' while processing query: 'SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')', required columns: 'n': While processing (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2: While processing n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2): While processing _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'): While processing if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'), n): While processing _CAST(if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery2), 'Int32'), n), 'Int32'). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000299b56b6 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:649: 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 @ 0x0000000029395dfb 6. ./build_docker/./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) @ 0x000000002938c51e 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:212: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029386230 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:259: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000294f05b8 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000294ecbff 10. ./contrib/llvm-project/libcxx/include/vector:432: DB::getQueryInterpreter(DB::ASTSubquery const&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e655e 11. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:0: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295dec84 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295de6bd 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 16. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 17. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 20. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 21. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 22. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 23. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 24. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x00000000299bbc53 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1507: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299bebf9 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b8a22 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2162 31. ./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) @ 0x00000000295a6166 2025.10.23 23:43:46.628715 [ 3077 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.011393 [ 3090 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.340605 [ 3094 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:47.684123 [ 3099 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.014243 [ 3101 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.343873 [ 3115 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.687617 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:48.984038 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.017625 [ 3129 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.416735 [ 3125 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:49.690791 [ 3148 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.021034 [ 3162 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.149295 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.419496 [ 3178 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.693662 [ 3185 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:50.902419 [ 17479 ] {629c1658-bd4e-4012-b5a6-db52749d9e1d} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 512.79 MiB (attempt to allocate chunk of 134479872 bytes), maximum: 476.84 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59980) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (in query: select key, groupArray(repeat('a', 200)), count() from data_01513 group by key format Null settings optimize_aggregation_in_order=0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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>&&) @ 0x000000001ae006bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfee3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000cf712be 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000cf70fdf 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:434: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000022991e56 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x00000000287d66b8 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch>, false>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000028b8e798 13. ./build_docker/./src/Interpreters/Aggregator.cpp:892: void DB::Aggregator::executeImpl>, false>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000028b88da5 14. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl>, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000028947049 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000287d1e8d 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1475: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000287dc5b0 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000002d980f15 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x000000002d97b015 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:51.024229 [ 3175 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.287822 [ 17479 ] {629c1658-bd4e-4012-b5a6-db52749d9e1d} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 512.79 MiB (attempt to allocate chunk of 134479872 bytes), maximum: 476.84 MiB.: While executing AggregatingTransform. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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>&&) @ 0x000000001ae006bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfee3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000cf712be 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000cf70fdf 10. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:434: DB::IAggregateFunctionHelper>>::addBatch(unsigned long, unsigned long, char**, unsigned long, DB::IColumn const**, DB::Arena*, long) const @ 0x0000000022991e56 11. ./contrib/llvm-project/libcxx/include/vector:547: DB::Aggregator::executeAggregateInstructions(DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, std::unique_ptr> const&, unsigned long, bool, bool, bool) const @ 0x00000000287d66b8 12. ./build_docker/./src/Interpreters/Aggregator.cpp:1079: void DB::Aggregator::executeImplBatch>, false>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, bool, char*) const @ 0x0000000028b8e798 13. ./build_docker/./src/Interpreters/Aggregator.cpp:892: void DB::Aggregator::executeImpl>, false>, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::ColumnsHashing::HashMethodString, char*, true, false, false, false>&, DB::Arena*, unsigned long, unsigned long, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x0000000028b88da5 14. ./build_docker/./src/Interpreters/Aggregator.cpp:835: void DB::Aggregator::executeImpl>, false>>(DB::AggregationMethodStringNoCache>, false>&, DB::Arena*, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, DB::ColumnsHashing::LastElementCacheStats&, bool, bool, char*) const @ 0x0000000028947049 15. ./build_docker/./src/Interpreters/Aggregator.cpp:0: DB::Aggregator::executeImpl(DB::AggregatedDataVariants&, unsigned long, unsigned long, std::vector>&, DB::Aggregator::AggregateFunctionInstruction*, bool, bool, char*) const @ 0x00000000287d1e8d 16. ./build_docker/./src/Interpreters/Aggregator.cpp:1475: DB::Aggregator::executeOnBlock(std::vector::immutable_ptr, std::allocator::immutable_ptr>>, unsigned long, unsigned long, DB::AggregatedDataVariants&, std::vector>&, std::vector>, std::allocator>>>&, bool&) const @ 0x00000000287dc5b0 17. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:692: DB::AggregatingTransform::consume(DB::Chunk) @ 0x000000002d980f15 18. ./build_docker/./src/Processors/Transforms/AggregatingTransform.cpp:0: DB::AggregatingTransform::work() @ 0x000000002d97b015 19. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 20. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 23. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 2025.10.23 23:43:51.423673 [ 3193 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:51.698793 [ 3199 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.027686 [ 3208 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.427530 [ 3220 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:52.701784 [ 3152 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.031037 [ 3230 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.430468 [ 3235 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:53.705081 [ 3248 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.034122 [ 3251 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.151530 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.433523 [ 3258 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:54.708774 [ 3267 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.109061 [ 3250 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.287787 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.436704 [ 3147 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:55.714034 [ 3272 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.112118 [ 2786 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.440065 [ 2789 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:56.717719 [ 2781 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.176519 [ 2811 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.362411 [ 18922 ] {8dd41d5c-dffa-4fe4-bbd8-2405745eecbb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57924) (comment: 02385_profile_events_overflow.sql) (in query: INSERT INTO t SELECT value FROM system.events WHERE event = 'OverflowBreak';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d362b87 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:43:57.365086 [ 18922 ] {8dd41d5c-dffa-4fe4-bbd8-2405745eecbb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=1, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/CompletedPipelineExecutor.cpp:57: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::CompletedPipelineExecutor::execute()::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d362b87 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:43:57.443382 [ 2831 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:57.721452 [ 2826 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.180444 [ 2819 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.271872 [ 15589 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.448747 [ 2824 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:58.724358 [ 2852 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.184126 [ 2854 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.249216 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.452420 [ 2841 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.743437 [ 2874 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:43:59.914370 [ 18922 ] {7ad9c528-cebe-4fbd-af8b-f02c12bf0689} 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.10542.altinitytest (altinity build)) (from [::1]:57934) (comment: 02346_position_countsubstrings_zero_byte.sql) (in query: select positionCaseInsensitiveUTF8('aaaaa\0x', pattern) from tab where id = 2;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:43:59.920332 [ 18922 ] {7ad9c528-cebe-4fbd-af8b-f02c12bf0689} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:44:00.187455 [ 2861 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.454033 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.455341 [ 2890 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:00.746808 [ 2903 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.190735 [ 2845 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.459849 [ 2931 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:01.749735 [ 2927 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.203996 [ 2926 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.462889 [ 2932 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:02.752284 [ 2959 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.207623 [ 2955 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.465593 [ 2952 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:03.755437 [ 2974 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.211069 [ 2980 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.335546 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.469185 [ 2976 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.767541 [ 3003 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:04.931654 [ 18922 ] {e013d08d-e704-495b-a3a8-6d23252a4620} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:57954) (comment: 00942_mv_rename_table.sql) (in query: DROP TABLE src_00942;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:44:04.936877 [ 18922 ] {e013d08d-e704-495b-a3a8-6d23252a4620} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:44:05.214402 [ 3012 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:05.474144 [ 3027 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:05.608070 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:05.771322 [ 3033 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.217940 [ 3041 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.478082 [ 3040 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:06.774863 [ 3056 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.221691 [ 3036 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.345195 [ 18922 ] {2eecbeab-be8f-4cbe-a9c4-fc9efc2c9e4b} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=9, jobs=9). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48760) (comment: 02457_morton_coding.sql) (in query: insert into morton_numbers_02457 select n1.number, n2.number, n3.number, n4.number, n5.number, n6.number, n7.number, n8.number from numbers(256-4, 4) n1 cross join numbers(256-4, 4) n2 cross join numbers(256-4, 4) n3 cross join numbers(256-4, 4) n4 cross join numbers(256-4, 4) n5 cross join numbers(256-4, 4) n6 cross join numbers(256-4, 4) n7 cross join numbers(256-4, 4) n8 ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:44:07.377675 [ 18922 ] {2eecbeab-be8f-4cbe-a9c4-fc9efc2c9e4b} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:44:07.482001 [ 3059 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:07.778725 [ 3052 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.226899 [ 3090 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.524933 [ 3078 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:08.746856 [ 18922 ] {2cfda6e6-2b4c-4289-941d-801f2cf12694} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=733). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48764) (comment: 00420_null_in_scalar_subqueries.sql) (in query: SELECT (SELECT Null WHERE nuLL IS NOT NULL);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:543: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028382400 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372a4f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:44:08.769863 [ 18922 ] {2cfda6e6-2b4c-4289-941d-801f2cf12694} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=733). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:543: DB::QueryAnalyzer::evaluateScalarSubqueryIfNeeded(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x0000000028382400 9. ./contrib/llvm-project/libcxx/include/vector:553: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x0000000028372a4f 10. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 11. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 12. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 13. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 14. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 15. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 16. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 17. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 18. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 19. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:44:08.794716 [ 3093 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.230159 [ 3104 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.454139 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.527930 [ 3073 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:09.799287 [ 3116 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.233733 [ 3126 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.531671 [ 3143 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.684425 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:10.803309 [ 3161 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.237081 [ 3169 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.410873 [ 18922 ] {7895037a-40d1-455f-97d3-8465c0f026c9} executeQuery: Code: 10. DB::Exception: Column `id` not found in table test_13.datetime_table (37a5fcee-854a-4539-943c-00419fd02bf3). (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48772) (comment: 03165_storage_merge_view_prewhere.sql) (in query: SELECT id, whatever FROM ids AS l INNER JOIN merge(currentDatabase(), 'data*') AS s ON l.id = s.id WHERE (status IN ['CREATED', 'CREATING']) ORDER BY event_time DESC ;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:213: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x000000002bd69e7e 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000002de38555 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000002c67674c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000002c65118b 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000002c650cc3 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002cbc95d4 10. ./build_docker/./src/Storages/StorageMerge.cpp:1186: DB::ReadFromMerge::createPlanForTable(std::shared_ptr const&, DB::SelectQueryInfo&, DB::QueryProcessingStage::Enum, unsigned long, std::tuple, std::shared_ptr, String> const&, std::vector>&&, std::optional const&, std::shared_ptr, unsigned long) const @ 0x000000002b99622c 11. ./build_docker/./src/Storages/StorageMerge.cpp:646: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x000000002b98b93f 12. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x000000002b983149 13. ./build_docker/./src/Storages/StorageMerge.cpp:1582: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000002b9a4406 14. ./contrib/llvm-project/libcxx/include/vector:590: DB::SourceStepWithFilter::applyFilters() @ 0x000000002dfaf715 15. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:0: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000002dfaf34a 16. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df7ea46 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de1cb4a 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1b5cb 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:44:11.417838 [ 18922 ] {7895037a-40d1-455f-97d3-8465c0f026c9} TCPHandler: Code: 10. DB::Exception: Column `id` not found in table test_13.datetime_table (37a5fcee-854a-4539-943c-00419fd02bf3). (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Storages/StorageSnapshot.cpp:213: DB::StorageSnapshot::getSampleBlockForColumns(std::vector> const&) const @ 0x000000002bd69e7e 5. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::ReadFromMergeTree(std::vector, std::allocator>>, std::shared_ptr, std::vector>, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr const&, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, std::shared_ptr, bool, std::optional>, std::optional (DB::ParallelReadRequest)>>, std::optional) @ 0x000000002de38555 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: std::__unique_if::__unique_single std::make_unique[abi:v15007], std::allocator>>, std::shared_ptr, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&>(std::vector, std::allocator>>&&, std::shared_ptr&&, std::vector> const&, DB::MergeTreeData const&, DB::SelectQueryInfo const&, std::shared_ptr const&, std::shared_ptr&, unsigned long const&, unsigned long const&, std::shared_ptr, std::equal_to, std::allocator>>>&, std::shared_ptr const&, std::shared_ptr&, bool&) @ 0x000000002c67674c 7. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:928: DB::MergeTreeDataSelectExecutor::readFromParts(std::vector, std::allocator>>, std::shared_ptr, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, std::shared_ptr, bool) const @ 0x000000002c65118b 8. ./build_docker/./src/Storages/MergeTree/MergeTreeDataSelectExecutor.cpp:137: DB::MergeTreeDataSelectExecutor::read(std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo const&, std::shared_ptr, unsigned long, unsigned long, std::shared_ptr, std::equal_to, std::allocator>>>, bool) const @ 0x000000002c650cc3 9. ./build_docker/./src/Storages/StorageMergeTree.cpp:249: DB::StorageMergeTree::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002cbc95d4 10. ./build_docker/./src/Storages/StorageMerge.cpp:1186: DB::ReadFromMerge::createPlanForTable(std::shared_ptr const&, DB::SelectQueryInfo&, DB::QueryProcessingStage::Enum, unsigned long, std::tuple, std::shared_ptr, String> const&, std::vector>&&, std::optional const&, std::shared_ptr, unsigned long) const @ 0x000000002b99622c 11. ./build_docker/./src/Storages/StorageMerge.cpp:646: DB::ReadFromMerge::createChildrenPlans(DB::SelectQueryInfo&) const @ 0x000000002b98b93f 12. ./build_docker/./src/Storages/StorageMerge.cpp:0: DB::ReadFromMerge::filterTablesAndCreateChildrenPlans() @ 0x000000002b983149 13. ./build_docker/./src/Storages/StorageMerge.cpp:1582: DB::ReadFromMerge::applyFilters(DB::ActionDAGNodes) @ 0x000000002b9a4406 14. ./contrib/llvm-project/libcxx/include/vector:590: DB::SourceStepWithFilter::applyFilters() @ 0x000000002dfaf715 15. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizePrimaryKeyConditionAndLimit.cpp:0: DB::QueryPlanOptimizations::optimizePrimaryKeyConditionAndLimit(std::vector> const&) @ 0x000000002dfaf34a 16. ./build_docker/./src/Processors/QueryPlan/Optimizations/optimizeTree.cpp:122: DB::QueryPlanOptimizations::optimizeTreeSecondPass(DB::QueryPlanOptimizationSettings const&, DB::QueryPlan::Node&, std::list>&) @ 0x000000002df7ea46 17. ./build_docker/./src/Processors/QueryPlan/QueryPlan.cpp:507: DB::QueryPlan::optimize(DB::QueryPlanOptimizationSettings const&) @ 0x000000002de1cb4a 18. ./contrib/llvm-project/libcxx/include/__memory/compressed_pair.h:36: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1b5cb 19. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 20. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 21. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 22. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 23. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 24. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 25. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 27. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 28. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 29. asan_thread_start(void*) @ 0x000000000aa47059 30. ? @ 0x00007f7519d19ac3 31. ? @ 0x00007f7519dab850 2025.10.23 23:44:11.534817 [ 3153 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:11.806302 [ 3192 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:12.240245 [ 3196 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:12.541688 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:12.809923 [ 3222 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.243211 [ 3229 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.545405 [ 3238 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.788777 [ 15589 ] {} virtual DB::WriteBufferFromHTTPServerResponse::~WriteBufferFromHTTPServerResponse(): Code: 210. DB::NetException: I/O error: Broken pipe, while writing to socket ([::ffff:127.0.0.1]:8123 -> [::ffff:127.0.0.1]:33050). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:116: DB::WriteBufferFromPocoSocket::socketSendBytes(char const*, unsigned long) @ 0x000000001b0bdb6a 4. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:0: DB::WriteBufferFromHTTPServerResponse::writeHeaderProgressImpl(char const*) @ 0x000000002d1f4e6a 5. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:93: DB::WriteBufferFromHTTPServerResponse::finishSendHeaders() @ 0x000000002d1f5848 6. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:0: DB::WriteBufferFromHTTPServerResponse::finalizeImpl() @ 0x000000002d1f708e 7. DB::WriteBuffer::finalize() @ 0x000000000aad12aa 8. ./build_docker/./src/Server/HTTP/WriteBufferFromHTTPServerResponse.cpp:180: DB::WriteBufferFromHTTPServerResponse::~WriteBufferFromHTTPServerResponse() @ 0x000000002d1f6de9 9. ./build_docker/./src/Server/WebUIRequestHandler.cpp:44: DB::handle(DB::HTTPServerRequest&, DB::HTTPServerResponse&, std::basic_string_view>, std::unordered_map, std::equal_to, std::allocator>>) @ 0x000000002d1dbc79 10. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::JavaScriptWebUIRequestHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d1dceef 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:13.817579 [ 3242 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.246490 [ 3227 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.537119 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.548658 [ 3277 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:14.821270 [ 3270 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.249660 [ 2796 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.552459 [ 3280 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.788352 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:15.824911 [ 2778 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.253041 [ 2776 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.555972 [ 2812 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:16.828582 [ 2784 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.256806 [ 2837 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.559710 [ 2818 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:17.831759 [ 2850 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.260706 [ 2857 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.563083 [ 2869 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:18.838206 [ 2851 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.265877 [ 2848 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.568496 [ 2888 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.706694 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:19.841618 [ 2889 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.269142 [ 2883 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.571427 [ 2886 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.844823 [ 2902 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:20.951630 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.272125 [ 2938 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.574297 [ 2946 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:21.848187 [ 2943 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.200554 [ 3379 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_265_290_5}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.274636 [ 2973 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.577397 [ 2974 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:22.628162 [ 18922 ] {58ef5d35-9d8b-4d18-8034-b857d2daf2ea} executeQuery: Code: 10. DB::Exception: Wrong column name. Cannot find column `non_existing_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58078) (comment: 01079_bad_alters_zookeeper_long.sh) (in query: ALTER TABLE table_for_bad_alters MODIFY COLUMN value1 UInt32, DROP COLUMN non_existing_column), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:44:22.636103 [ 18922 ] {58ef5d35-9d8b-4d18-8034-b857d2daf2ea} TCPHandler: Code: 10. DB::Exception: Wrong column name. Cannot find column `non_existing_column` to drop. (NOT_FOUND_COLUMN_IN_BLOCK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Storages/AlterCommands.cpp:1508: DB::AlterCommands::validate(std::shared_ptr const&, std::shared_ptr) const @ 0x000000002b6168e7 4. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:207: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291801b2 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:44:22.851997 [ 2984 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.277842 [ 2992 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.591932 [ 3003 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:23.855024 [ 3008 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.281293 [ 3037 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.360612 [ 3388 ] {} 4964c6ef-1e2c-436d-a3f6-45759549cba4::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/496/4964c6ef-1e2c-436d-a3f6-45759549cba4/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000adccd62 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000adbb3d6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000ad4f0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf6e8b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd27e4 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002870b0fd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000029b797ba 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000002c7d4fd6 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x000000002c823035 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d38ae96 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000002c917192 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000002c95ceea 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000002c954494 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x000000002c91dc9f (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.362656 [ 3388 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4964c6ef-1e2c-436d-a3f6-45759549cba4::all_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/496/4964c6ef-1e2c-436d-a3f6-45759549cba4/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000adccd62 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000adbb3d6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000ad4f0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf6e8b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd27e4 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002870b0fd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000029b797ba 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000002c7d4fd6 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x000000002c823035 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d38ae96 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000002c917192 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000002c95ceea 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000002c954494 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x000000002c91dc9f (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.595542 [ 3043 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.858587 [ 2997 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:24.874334 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.096382 [ 3383 ] {} 4964c6ef-1e2c-436d-a3f6-45759549cba4::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/496/4964c6ef-1e2c-436d-a3f6-45759549cba4/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000adccd62 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000adbb3d6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000ad4f0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf6e8b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd27e4 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002870b0fd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000029b797ba 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000002c7d4fd6 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x000000002c823035 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d38ae96 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000002c917192 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000002c95ceea 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000002c954494 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x000000002c91dc9f (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.099189 [ 3383 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4964c6ef-1e2c-436d-a3f6-45759549cba4::all_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/496/4964c6ef-1e2c-436d-a3f6-45759549cba4/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000adccd62 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000adbb3d6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000ad4f0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf6e8b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd27e4 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002870b0fd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000029b797ba 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000002c7d4fd6 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x000000002c823035 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d38ae96 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000002c917192 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000002c95ceea 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000002c954494 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x000000002c91dc9f (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.285021 [ 3045 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.622525 [ 3060 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:25.862567 [ 3069 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.145214 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.209355 [ 3382 ] {} 4964c6ef-1e2c-436d-a3f6-45759549cba4::all_0_0_0_1 (MutateFromLogEntryTask): virtual bool DB::ReplicatedMergeMutateTaskBase::executeStep(): Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/496/4964c6ef-1e2c-436d-a3f6-45759549cba4/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000adccd62 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000adbb3d6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000ad4f0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf6e8b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd27e4 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002870b0fd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000029b797ba 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000002c7d4fd6 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x000000002c823035 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d38ae96 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000002c917192 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000002c95ceea 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000002c954494 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x000000002c91dc9f (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.212137 [ 3382 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {4964c6ef-1e2c-436d-a3f6-45759549cba4::all_0_0_0_1}: Code: 6. DB::Exception: Cannot parse string 'Hello' as UInt32: syntax error at begin of string. Note: there are toUInt32OrZero and toUInt32OrNull functions, which returns zero/NULL instead of throwing exception.: while executing 'FUNCTION _CAST(value2 :: 2, 'UInt32' :: 3) -> _CAST(value2, 'UInt32') UInt32 : 4': (while reading from part /var/lib/clickhouse/store/496/4964c6ef-1e2c-436d-a3f6-45759549cba4/all_0_0_0/ located on disk default of type local): While executing MergeTreeSequentialSource. (CANNOT_PARSE_TEXT), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::(anonymous namespace)::throwExceptionForIncompletelyParsedValue(DB::ReadBuffer&, DB::IDataType const&) @ 0x000000000ad074ef 4. bool DB::callOnIndexAndDataType, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString>(DB::TypeIndex, DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeInternal(std::vector> const&, std::shared_ptr const&, unsigned long) const::'lambda'(auto const&, DB::(anonymous namespace)::BehaviourOnErrorFromString)&, DB::(anonymous namespace)::BehaviourOnErrorFromString&&) @ 0x000000000adccd62 5. DB::(anonymous namespace)::FunctionConvert, DB::(anonymous namespace)::NameToUInt32, DB::(anonymous namespace)::ToNumberMonotonicity>::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000adbb3d6 6. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 7. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 8. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 9. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 10. DB::IFunctionBase::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000aacbd8f 11. COW::immutable_ptr std::__function::__policy_invoker::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>::__call_impl, std::shared_ptr const&)::'lambda'(std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long), COW::immutable_ptr (std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long)>>(std::__function::__policy_storage const*, std::vector>&, std::shared_ptr const&, DB::ColumnNullable const*, unsigned long) @ 0x000000000ad4f0e1 12. DB::(anonymous namespace)::ExecutableFunctionCast::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000acf6e8b 13. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 14. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd27e4 15. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 16. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 17. ./contrib/llvm-project/libcxx/include/vector:547: DB::ExpressionActions::execute(DB::Block&, bool, bool) const @ 0x000000002870b0fd 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::performRequiredConversions(DB::Block&, DB::NamesAndTypesList const&, std::shared_ptr) @ 0x0000000029b797ba 19. ./build_docker/./src/Storages/MergeTree/IMergeTreeReader.cpp:311: DB::IMergeTreeReader::performRequiredConversions(std::vector::immutable_ptr, std::allocator::immutable_ptr>>&) const @ 0x000000002c7d4fd6 20. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:247: DB::MergeTreeSequentialSource::generate() @ 0x000000002c823035 21. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 22. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 23. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 24. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 25. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:150: DB::PipelineExecutor::executeStep(std::atomic*) @ 0x000000002d3657d2 26. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:54: DB::PullingPipelineExecutor::pull(DB::Chunk&) @ 0x000000002d38a936 27. ./build_docker/./src/Processors/Executors/PullingPipelineExecutor.cpp:65: DB::PullingPipelineExecutor::pull(DB::Block&) @ 0x000000002d38ae96 28. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1322: DB::PartMergerWriter::mutateOriginalPartAndPrepareProjections() @ 0x000000002c917192 29. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::PartMergerWriter::execute() @ 0x000000002c95ceea 30. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:1463: DB::MutateAllPartColumnsTask::executeStep() @ 0x000000002c954494 31. ./build_docker/./src/Storages/MergeTree/MutateTask.cpp:0: DB::MutateTask::execute() @ 0x000000002c91dc9f (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.288419 [ 3084 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.587068 [ 3379 ] {} test_13.table_for_bad_alters (ReplicatedMergeTreeQueue): There are no mutations for partition ID all (trying to mutate part all_0_0_0 to 1) 2025.10.23 23:44:26.626173 [ 3072 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:26.891188 [ 3076 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.291692 [ 3106 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.629454 [ 3119 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:27.894729 [ 3131 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.319808 [ 3137 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.337632 [ 15589 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.634801 [ 3103 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:28.897879 [ 3156 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.336470 [ 3188 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.638701 [ 3174 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:29.901138 [ 3166 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.027348 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.339203 [ 3199 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.509983 [ 18922 ] {cf45b40e-45d2-48ac-8707-7ffe0e534941} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42188) (comment: 01079_bad_alters_zookeeper_long.sh) (in query: SELECT distinct(value2) FROM table_for_bad_alters), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:44:30.527218 [ 18922 ] {cf45b40e-45d2-48ac-8707-7ffe0e534941} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:44:30.641886 [ 3211 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:30.904224 [ 3151 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.320504 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.377526 [ 3238 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.645120 [ 3254 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:31.908383 [ 3265 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.380670 [ 3253 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.648750 [ 3279 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:32.911463 [ 2790 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.383664 [ 2806 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.651895 [ 2777 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:33.920016 [ 2782 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.104961 [ 18922 ] {6c7874bd-f335-4a78-9d4d-4acd66198165} executeQuery: Code: 36. DB::Exception: Wrong index name. Cannot find index `idx2` to drop. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42224) (comment: 01079_bad_alters_zookeeper_long.sh) (in query: ALTER TABLE table_for_bad_alters DROP INDEX idx2), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cf0ba 4. ./build_docker/./src/Storages/AlterCommands.cpp:692: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b6052e9 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b60c05c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a5450 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180212 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:44:34.110376 [ 18922 ] {6c7874bd-f335-4a78-9d4d-4acd66198165} TCPHandler: Code: 36. DB::Exception: Wrong index name. Cannot find index `idx2` to drop. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&) @ 0x000000000e9cf0ba 4. ./build_docker/./src/Storages/AlterCommands.cpp:692: DB::AlterCommand::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b6052e9 5. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::AlterCommands::apply(DB::StorageInMemoryMetadata&, std::shared_ptr) const @ 0x000000002b60c05c 6. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4a5450 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180212 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:44:34.386618 [ 2784 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.662180 [ 2810 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:34.925343 [ 2837 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.113892 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.390345 [ 2824 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.665052 [ 2849 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:35.928182 [ 2847 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.393367 [ 2841 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.395386 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.669423 [ 2875 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:36.931790 [ 2881 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.396785 [ 2888 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.673604 [ 2853 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:37.935246 [ 2908 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.400433 [ 2904 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.677205 [ 2845 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:38.938468 [ 2923 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.404110 [ 2921 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.681050 [ 2928 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:39.941221 [ 2946 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.189199 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.409101 [ 2944 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.684906 [ 2967 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:40.944514 [ 2966 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.412300 [ 2953 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.551967 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.757499 [ 2982 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:41.948067 [ 2990 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.119735 [ 4049 ] {3b59d6c8-32f6-4da6-b90d-e229f92944c4} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48792) (comment: 02711_soundex_function.sql) (in query: CREATE TABLE tab (`col` String) ENGINE = MergeTree ORDER BY col SETTINGS index_granularity = 63696, min_bytes_for_wide_part = 1073741824, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 93, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 385699998, compact_parts_max_granules_to_buffer = 1, compact_parts_merge_max_bytes_to_prefetch_part = 26070167, merge_max_block_size = 22001, old_parts_lifetime = 339., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 502915, vertical_merge_algorithm_min_columns_to_activate = 1, min_merge_bytes_to_use_direct_io = 2034729939, index_granularity_bytes = 1888285, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 16909, primary_key_compress_block_size = 81770), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:44:42.121773 [ 4049 ] {3b59d6c8-32f6-4da6-b90d-e229f92944c4} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:44:42.415606 [ 3006 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.761330 [ 3007 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:42.951077 [ 3016 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.418953 [ 3005 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.832836 [ 3037 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:43.958238 [ 3039 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.425040 [ 3030 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.836189 [ 3055 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:44.964390 [ 3063 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.334831 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.427561 [ 3060 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.839960 [ 3074 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:45.967638 [ 3090 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.430552 [ 3094 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.669675 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.843092 [ 3076 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:46.971062 [ 3101 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.427164 [ 3381 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {7375513c-4863-4bde-85c7-c66f94b39dbd::202510_1_141_28}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.432966 [ 3120 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.611564 [ 4221 ] {ccc1f0a6-114f-4066-811a-f9e6f9914851} void DB::ParallelParsingInputFormat::onBackgroundException(): Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215). (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7d4ba 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:399: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x00000000229417cb 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:684: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000229912cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:127: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000027abb9b9 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027abcdca 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000027b8d0ef 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:787: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b88e31 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000002d540ccf 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:252: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4d6850 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d48a305 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d396ee6 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 15. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d716f89 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d713c21 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.620663 [ 4049 ] {ccc1f0a6-114f-4066-811a-f9e6f9914851} executeQuery: Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215): While executing ParallelParsingBlockInputFormat. (TOO_LARGE_ARRAY_SIZE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54464) (comment: 02681_group_array_too_large_size.sql) (in query: -- This query throw high-level exception instead of low-level "too large size passed to allocator": SELECT * FROM format(CSV, 'entitypArray AggregateFunction(groupArray, String)', '295TMiews.viewNÿÿÿÿÿ""""""TabSeparÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿÿated d St"" r');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7d4ba 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:399: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x00000000229417cb 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:684: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000229912cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:127: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000027abb9b9 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027abcdca 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000027b8d0ef 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:787: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b88e31 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000002d540ccf 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:252: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4d6850 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d48a305 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d396ee6 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 15. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d716f89 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d713c21 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:44:47.623758 [ 4049 ] {ccc1f0a6-114f-4066-811a-f9e6f9914851} TCPHandler: Code: 128. DB::Exception: Too large array element size 18446744073709551615 (maximum: 16777215): While executing ParallelParsingBlockInputFormat. (TOO_LARGE_ARRAY_SIZE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, unsigned long&, unsigned long&) @ 0x000000000cf7d4ba 4. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:399: DB::(anonymous namespace)::GroupArrayNodeBase::read(DB::ReadBuffer&, DB::Arena*) @ 0x00000000229417cb 5. ./build_docker/./src/AggregateFunctions/AggregateFunctionGroupArray.cpp:684: DB::(anonymous namespace)::GroupArrayGeneralImpl>::deserialize(char*, DB::ReadBuffer&, std::optional, DB::Arena*) const @ 0x00000000229912cc 6. ./build_docker/./src/DataTypes/Serializations/SerializationAggregateFunction.cpp:127: DB::deserializeFromString(std::shared_ptr const&, DB::IColumn&, String const&, unsigned long) @ 0x0000000027abb9b9 7. ./contrib/llvm-project/libcxx/include/string:1499: DB::SerializationAggregateFunction::deserializeTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&) const @ 0x0000000027abcdca 8. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:0: void DB::deserializeTextCSVImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&, bool&) @ 0x0000000027b8d0ef 9. ./build_docker/./src/DataTypes/Serializations/SerializationNullable.cpp:787: DB::SerializationNullable::deserializeNullAsDefaultOrNestedTextCSV(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, std::shared_ptr const&) @ 0x0000000027b88e31 10. ./build_docker/./src/Processors/Formats/Impl/CSVRowInputFormat.cpp:388: DB::CSVFormatReader::readField(DB::IColumn&, std::shared_ptr const&, std::shared_ptr const&, bool, String const&) @ 0x000000002d540ccf 11. ./build_docker/./src/Processors/Formats/RowInputFormatWithNamesAndTypes.cpp:252: DB::RowInputFormatWithNamesAndTypes::readRow(std::vector::mutable_ptr, std::allocator::mutable_ptr>>&, DB::RowReadExtension&) @ 0x000000002d4d6850 12. ./build_docker/./src/Processors/Formats/IRowInputFormat.cpp:0: DB::IRowInputFormat::read() @ 0x000000002d48a305 13. ./build_docker/./src/Processors/Formats/IInputFormat.cpp:19: DB::IInputFormat::generate() @ 0x000000002d396ee6 14. ./src/Processors/Chunk.h:110: DB::ISource::tryGenerate() @ 0x000000002d3463b8 15. ./build_docker/./src/Processors/ISource.cpp:0: DB::ISource::work() @ 0x000000002d345841 16. ./src/Processors/Formats/Impl/ParallelParsingInputFormat.h:0: DB::ParallelParsingInputFormat::InternalParser::getChunk() @ 0x000000002d716f89 17. ./contrib/llvm-project/libcxx/include/vector:961: DB::ParallelParsingInputFormat::parserThreadFunction(std::shared_ptr, unsigned long) @ 0x000000002d713c21 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 19. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 20. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 22. asan_thread_start(void*) @ 0x000000000aa47059 23. ? @ 0x00007f7519d19ac3 24. ? @ 0x00007f7519dab850 2025.10.23 23:44:47.846075 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:47.974157 [ 3131 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.438581 [ 3140 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.681037 [ 18099 ] {5ab76567-5bec-44b5-84b4-22320a7431af} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:37264) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:44:48.691700 [ 18099 ] {5ab76567-5bec-44b5-84b4-22320a7431af} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:44:48.848830 [ 3161 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:48.976687 [ 3163 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.444863 [ 3169 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.579986 [ 4049 ] {23d38c38-4b81-422b-a93a-950141659d40} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54488) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:44:49.593620 [ 4049 ] {23d38c38-4b81-422b-a93a-950141659d40} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=5, jobs=5). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:44:49.601421 [ 3178 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.754818 [ 3138 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.834485 [ 17481 ] {9a969b9c-2e53-4cf9-94ce-b57d5c51726d} executeQuery: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54500) (comment: 01329_compare_tuple_string_constant.sql) (in query: SELECT tuple(1) < '';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb6f35 4. ./src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000027c3d2b0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:554: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029ab2a8f 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aaeb61 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133fa110 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133c81d1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 2025.10.23 23:44:49.846367 [ 17481 ] {9a969b9c-2e53-4cf9-94ce-b57d5c51726d} TCPHandler: Code: 27. DB::Exception: Cannot parse input: expected '(' at end of stream.: while converting '' to Tuple(UInt8): In scope SELECT tuple(1) < ''. (CANNOT_PARSE_INPUT_ASSERTION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::throwAtAssertionFailed(char const*, DB::ReadBuffer&) @ 0x000000001aeb6f35 4. ./src/IO/ReadBuffer.h:114: void DB::SerializationTuple::deserializeTextImpl(DB::IColumn&, DB::ReadBuffer&, DB::FormatSettings const&, bool) const @ 0x0000000027c3d2b0 5. ./build_docker/./src/Interpreters/convertFieldToType.cpp:554: DB::(anonymous namespace)::convertFieldToTypeImpl(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029ab2a8f 6. ./build_docker/./src/Interpreters/convertFieldToType.cpp:611: DB::convertFieldToType(DB::Field const&, DB::IDataType const&, DB::IDataType const*) @ 0x0000000029aaeb61 7. DB::FunctionComparison::executeWithConstString(std::shared_ptr const&, DB::IColumn const*, DB::IColumn const*, std::shared_ptr const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133fa110 8. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133c81d1 9. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 10. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 11. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 12. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 13. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 14. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::QueryAnalyzer::resolveFunction(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283a4e6f 15. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveExpressionNode(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool, bool) @ 0x000000002837256e 16. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:3909: DB::QueryAnalyzer::resolveExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&, bool, bool) @ 0x0000000028370c30 17. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4160: DB::QueryAnalyzer::resolveProjectionExpressionNodeList(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c0d89 18. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x00000000283657a3 19. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 20. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 21. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 22. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 23. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 24. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 25. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 26. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 27. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 28. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 29. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 30. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 31. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 2025.10.23 23:44:49.886200 [ 3174 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:49.979821 [ 3168 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.193333 [ 17481 ] {13ab611e-2f0e-498c-ab07-005b7f48b98a} executeQuery: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54500) (comment: 01329_compare_tuple_string_constant.sql) (in query: SELECT tuple(1) < materialize('');), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000027a80c75 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:402: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a8a710 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000133fbf2a 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133c9b47 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./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) @ 0x0000000028263dc8 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000282617b7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9deb37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dda9bf9 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000029448613 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029440d00 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000029432a7b 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002942ddd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43d9e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:44:50.199262 [ 17481 ] {13ab611e-2f0e-498c-ab07-005b7f48b98a} TCPHandler: Code: 386. DB::Exception: There is no supertype for types Tuple(UInt8), String because some of them are Tuple and some of them are not. (NO_COMMON_TYPE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: std::shared_ptr DB::(anonymous namespace)::throwOrReturn<(DB::LeastSupertypeOnError)0, std::vector, std::allocator>>>(std::vector, std::allocator>> const&, std::basic_string_view>, int) @ 0x0000000027a80c75 4. ./build_docker/./src/DataTypes/getLeastSupertype.cpp:402: std::shared_ptr DB::getLeastSupertype<(DB::LeastSupertypeOnError)0>(std::vector, std::allocator>> const&) @ 0x0000000027a8a710 5. DB::FunctionComparison::executeGeneric(DB::ColumnWithTypeAndName const&, DB::ColumnWithTypeAndName const&) const @ 0x00000000133fbf2a 6. DB::FunctionComparison::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000133c9b47 7. DB::IFunction::executeImplDryRun(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aa90635 8. DB::FunctionToExecutableFunctionAdaptor::executeDryRunImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd1d5 9. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0cfb 10. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 11. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 12. ./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) @ 0x0000000028263dc8 13. ./contrib/llvm-project/libcxx/include/vector:961: DB::ActionsDAG::updateHeader(DB::Block const&) const @ 0x00000000282617b7 14. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:10: DB::ExpressionTransform::transformHeader(DB::Block const&, DB::ActionsDAG const&) @ 0x000000002d9deb37 15. ./build_docker/./src/Processors/QueryPlan/ExpressionStep.cpp:0: DB::ExpressionStep::ExpressionStep(DB::DataStream const&, DB::ActionsDAG) @ 0x000000002dda9bf9 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::(anonymous namespace)::addExpressionStep(DB::QueryPlan&, std::shared_ptr&, String const&, std::unordered_set, std::hash>, std::equal_to>, std::allocator>>&) @ 0x0000000029448613 17. ./contrib/llvm-project/libcxx/include/string:1499: DB::Planner::buildPlanForQueryNode() @ 0x0000000029440d00 18. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000029432a7b 19. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002942ddd2 20. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43d9e 21. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 22. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 23. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 24. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 26. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 27. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 28. asan_thread_start(void*) @ 0x000000000aa47059 29. ? @ 0x00007f7519d19ac3 30. ? @ 0x00007f7519dab850 2025.10.23 23:44:50.434306 [ 9638 ] {} DDLWorker(test_1_repl_01111_3): Error on initialization of test_1_repl_01111_3: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.524351 [ 3195 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.604274 [ 3196 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.692945 [ 3204 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.757966 [ 3207 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.889461 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:50.984146 [ 3219 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.526665 [ 3223 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.575844 [ 4049 ] {bf1995e7-1c9c-4aad-a890-e89141a692a8} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:54516) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_1_repl_01111_14), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:44:51.585549 [ 4049 ] {bf1995e7-1c9c-4aad-a890-e89141a692a8} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:44:51.613349 [ 3231 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.696289 [ 3234 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.760845 [ 3235 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.821566 [ 3552 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.892372 [ 3241 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:51.987304 [ 3248 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.054541 [ 3254 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.529698 [ 3255 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.616563 [ 3264 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.699973 [ 3258 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.720966 [ 3274 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.764935 [ 3269 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.895956 [ 3263 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:52.991428 [ 2774 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.057883 [ 3250 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.533715 [ 3183 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.619554 [ 2779 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.702894 [ 2796 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.724522 [ 3283 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.755524 [ 3249 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.771320 [ 2803 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.899116 [ 2806 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:53.994713 [ 2778 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.061350 [ 2788 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.296416 [ 3212 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.536491 [ 2780 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.623391 [ 2809 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.706437 [ 2797 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.728188 [ 2812 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.759031 [ 2813 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.774827 [ 2811 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.902365 [ 2784 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:54.997997 [ 2816 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.065208 [ 2827 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.299105 [ 2833 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.539701 [ 2829 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.626556 [ 2825 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.709828 [ 2837 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.731547 [ 2835 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.767037 [ 2832 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.777770 [ 2822 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:55.905043 [ 2839 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.014164 [ 2852 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.068440 [ 2842 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.301871 [ 2863 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.543342 [ 2854 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.642825 [ 2870 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.718786 [ 2868 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.734716 [ 2851 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.770591 [ 2875 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.780991 [ 2872 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:56.916789 [ 2876 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.018133 [ 2864 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.072394 [ 2848 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.304915 [ 2896 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.546669 [ 2891 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.646893 [ 2889 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.721331 [ 2897 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.737326 [ 2877 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.773842 [ 2903 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.785248 [ 2880 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:57.920613 [ 2883 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.024456 [ 2905 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.076328 [ 2794 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.307893 [ 2886 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.468354 [ 17481 ] {b9d78fc7-132b-49b5-88b7-0bc295871540} executeQuery: Code: 48. DB::Exception: Reading from a partitioned S3 storage is not implemented yet. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48126) (comment: 02302_s3_file_pruning.sql) (in query: select * from test_02302;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:262: DB::StorageObjectStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000267bd44a 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:856: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000294767a2 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1771: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002946a23d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029439226 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000029432a7b 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002942ddd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43d9e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:44:58.471676 [ 17481 ] {b9d78fc7-132b-49b5-88b7-0bc295871540} TCPHandler: Code: 48. DB::Exception: Reading from a partitioned S3 storage is not implemented yet. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:262: DB::StorageObjectStorage::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x00000000267bd44a 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:856: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000294767a2 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1771: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002946a23d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029439226 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000029432a7b 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002942ddd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43d9e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:44:58.549163 [ 2923 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.653211 [ 2925 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.725792 [ 2902 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.740526 [ 2924 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.776297 [ 2927 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.789275 [ 2895 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:58.924083 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.027801 [ 2930 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.086663 [ 2928 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.231919 [ 17481 ] {f0a0a46d-adaa-47d7-894a-32f3e7b4b607} 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.10542.altinitytest (altinity build)) (from [::1]:48126) (comment: 02302_s3_file_pruning.sql) (in query: -- Test s3 table function with glob select * from s3(s3_conn, filename='test_02302_*', format=Parquet) where _file like '%5';), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026b25bc2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026b255d4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000026b233e5 9. ./build_docker/./src/Disks/ObjectStorages/ObjectStorageIteratorAsync.cpp:112: DB::IObjectStorageIteratorAsync::isValid() @ 0x0000000026b243fe 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:532: DB::StorageObjectStorageSource::GlobIterator::estimatedKeysCount() @ 0x00000000267e7f3f 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::(anonymous namespace)::ReadFromObjectStorageStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000267c4ff0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 24. asan_thread_start(void*) @ 0x000000000aa47059 25. ? @ 0x00007f7519d19ac3 26. ? @ 0x00007f7519dab850 2025.10.23 23:44:59.257571 [ 17481 ] {f0a0a46d-adaa-47d7-894a-32f3e7b4b607} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x0000000026b25bc2 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:717: ? @ 0x0000000026b255d4 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x0000000026b233e5 9. ./build_docker/./src/Disks/ObjectStorages/ObjectStorageIteratorAsync.cpp:112: DB::IObjectStorageIteratorAsync::isValid() @ 0x0000000026b243fe 10. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorageSource.cpp:532: DB::StorageObjectStorageSource::GlobIterator::estimatedKeysCount() @ 0x00000000267e7f3f 11. ./build_docker/./src/Storages/ObjectStorage/StorageObjectStorage.cpp:0: DB::(anonymous namespace)::ReadFromObjectStorageStep::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x00000000267c4ff0 12. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 14. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 16. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 17. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 19. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 20. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 21. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 22. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 23. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 24. asan_thread_start(void*) @ 0x000000000aa47059 25. ? @ 0x00007f7519d19ac3 26. ? @ 0x00007f7519dab850 2025.10.23 23:44:59.310469 [ 2912 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.551508 [ 2941 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.656527 [ 2950 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.728900 [ 2935 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.743893 [ 2954 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.779288 [ 2959 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.791996 [ 2943 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:44:59.927416 [ 2955 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.030910 [ 2960 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.089691 [ 2969 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.313624 [ 2952 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.446931 [ 4281 ] {} DDLWorker(test_1_repl_01111_1): Error on initialization of test_1_repl_01111_1: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.553936 [ 2978 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.659799 [ 2953 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.718504 [ 4049 ] {1268cba3-e397-48f8-b7f4-3c8492edd944} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48176) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1.rmt_7924_12760_30222 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:00.736314 [ 2956 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.745792 [ 4049 ] {1268cba3-e397-48f8-b7f4-3c8492edd944} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:00.746672 [ 2968 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.782438 [ 2983 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.794280 [ 2783 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:00.932443 [ 2982 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.024048 [ 24853 ] {74fc1012-25fd-4fe8-b934-842d14332908} executeQuery: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48222) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.local_01099_b update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:01.033182 [ 2984 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.092817 [ 2999 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.134682 [ 24853 ] {74fc1012-25fd-4fe8-b934-842d14332908} TCPHandler: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:01.165238 [ 24921 ] {eea36d4a-e27c-4d7d-b4d4-3cbb03f5bcbe} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:bc4218bc-a34c-4204-974a-cc6d94163f09', current host ID: '793cd66ee8bf:9000:c01377d9-3b65-422b-85f7-7801b74967f0'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48236) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_5 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:01.196075 [ 24921 ] {eea36d4a-e27c-4d7d-b4d4-3cbb03f5bcbe} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:bc4218bc-a34c-4204-974a-cc6d94163f09', current host ID: '793cd66ee8bf:9000:c01377d9-3b65-422b-85f7-7801b74967f0'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:01.318330 [ 2994 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.556322 [ 2910 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.662526 [ 2970 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.739340 [ 2996 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.844189 [ 3001 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.844834 [ 3007 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.863412 [ 15589 ] {7894a459-2223-470d-81fa-9be9e0e5bfc1} 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.10542.altinitytest (altinity build)) (from [::1]:48244) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:45:01.881354 [ 3000 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:01.883273 [ 15589 ] {7894a459-2223-470d-81fa-9be9e0e5bfc1} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=2, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:45:01.935240 [ 3008 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.039941 [ 3016 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.095496 [ 3025 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.323290 [ 3019 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.558975 [ 3024 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.664881 [ 2997 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.684858 [ 17481 ] {e2c14a66-8aae-4986-af94-ea9eaa18b3c0} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48328) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_4344_4779_23737 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:02.706975 [ 17481 ] {e2c14a66-8aae-4986-af94-ea9eaa18b3c0} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:02.721585 [ 18099 ] {c114e650-61fb-4e47-9158-040bff660a51} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48338) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:02.741574 [ 3094 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.784677 [ 18099 ] {c114e650-61fb-4e47-9158-040bff660a51} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:02.846554 [ 3132 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.850719 [ 3126 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.883432 [ 3134 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.949189 [ 3136 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:02.969152 [ 3446 ] {} DDLWorker(test_1_repl_01111_5): Error on initialization of test_1_repl_01111_5: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.043561 [ 3165 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.104561 [ 3195 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.252273 [ 15589 ] {2c4b35d0-ce8e-41fb-b20a-b591dad95a01} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48358) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.pd update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:45:03.280450 [ 15589 ] {2c4b35d0-ce8e-41fb-b20a-b591dad95a01} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x000000002917e05f 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:45:03.325528 [ 3268 ] {} test_1_repl_01111_14.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.561253 [ 2837 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.667343 [ 2832 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.743557 [ 2822 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.782299 [ 24853 ] {8d898e91-722c-451b-972c-d34e28820c6d} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:7d45b4e4-2273-4c3c-91cd-3af80ee3ef8c', current host ID: '793cd66ee8bf:9000:b6a90a6b-cddb-4af4-a1c5-933b829f1509'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:48384) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_3 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:03.814742 [ 24853 ] {8d898e91-722c-451b-972c-d34e28820c6d} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:7d45b4e4-2273-4c3c-91cd-3af80ee3ef8c', current host ID: '793cd66ee8bf:9000:b6a90a6b-cddb-4af4-a1c5-933b829f1509'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:03.870819 [ 2849 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.874056 [ 2839 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.885351 [ 2850 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:03.959664 [ 2828 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.045913 [ 2842 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.106678 [ 2855 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.300079 [ 4049 ] {b2fc4384-735a-49d1-bf45-b39c5605b591} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58974) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_29807_22231_17461 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:04.320955 [ 4049 ] {b2fc4384-735a-49d1-bf45-b39c5605b591} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:04.567168 [ 2867 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.674886 [ 2851 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.745979 [ 2875 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.854698 [ 4049 ] {f202c459-a289-46d0-9ab6-fa65020a5637} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:b986794a-dd11-41c9-a3c6-38ac682ed9b1'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59018) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_2 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:04.866564 [ 4049 ] {f202c459-a289-46d0-9ab6-fa65020a5637} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:b986794a-dd11-41c9-a3c6-38ac682ed9b1'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:04.882577 [ 2938 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.882615 [ 2930 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.889137 [ 2885 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:04.963649 [ 2949 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.047944 [ 2965 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.109041 [ 2979 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.157527 [ 24853 ] {61dba331-f663-42d0-89e4-395e683a557a} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59020) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.dim_model update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:05.183071 [ 24853 ] {61dba331-f663-42d0-89e4-395e683a557a} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:05.570077 [ 2988 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.677149 [ 2984 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.758177 [ 2995 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.886132 [ 2976 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.886606 [ 2994 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.891116 [ 2977 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:05.965912 [ 2971 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.049968 [ 3057 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.111198 [ 3083 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.133105 [ 17481 ] {8a0d34a7-2491-47a3-a03b-fa171c393324} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59102) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_13466_21627_15158 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:06.144821 [ 17481 ] {8a0d34a7-2491-47a3-a03b-fa171c393324} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:06.361170 [ 17481 ] {5d16ea96-160c-4e41-a81a-861e80f1cf3c} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:7d45b4e4-2273-4c3c-91cd-3af80ee3ef8c', current host ID: '793cd66ee8bf:9000:a4fa338c-2dad-4191-bf1b-4620280d4d62'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59122) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_15 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:06.368723 [ 17481 ] {5d16ea96-160c-4e41-a81a-861e80f1cf3c} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:7d45b4e4-2273-4c3c-91cd-3af80ee3ef8c', current host ID: '793cd66ee8bf:9000:a4fa338c-2dad-4191-bf1b-4620280d4d62'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:06.439781 [ 15589 ] {505d61a1-72ee-487d-abef-4c49d1b27056} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59138) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:06.452805 [ 15589 ] {505d61a1-72ee-487d-abef-4c49d1b27056} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:06.585550 [ 3260 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.679418 [ 3272 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.762022 [ 3273 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.888371 [ 2778 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.888705 [ 2788 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.893641 [ 2789 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:06.969550 [ 2777 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.052638 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.123323 [ 2782 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.136330 [ 17481 ] {5509658c-9c24-4dd9-8063-6d3193c4e142} executeQuery: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59178) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.local_01099_b update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:07.151901 [ 17481 ] {5509658c-9c24-4dd9-8063-6d3193c4e142} TCPHandler: Code: 48. DB::Exception: Table engine Log doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:07.395241 [ 15589 ] {a24e2f22-3498-4556-b345-1051e352123f} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:7d45b4e4-2273-4c3c-91cd-3af80ee3ef8c', current host ID: '793cd66ee8bf:9000:dc60adcf-93dc-45f3-84ed-e812f99e8c2a'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59212) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_10 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:07.398327 [ 15589 ] {a24e2f22-3498-4556-b345-1051e352123f} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:7d45b4e4-2273-4c3c-91cd-3af80ee3ef8c', current host ID: '793cd66ee8bf:9000:dc60adcf-93dc-45f3-84ed-e812f99e8c2a'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:07.409100 [ 24921 ] {f5f30a86-a97e-45f1-8283-d3f457fb8399} 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.10542.altinitytest (altinity build)) (from [::1]:59202) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:45:07.426761 [ 24921 ] {f5f30a86-a97e-45f1-8283-d3f457fb8399} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000292037ea 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 9. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 10. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 11. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 12. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 13. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 14. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 15. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 17. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 18. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 19. asan_thread_start(void*) @ 0x000000000aa47059 20. ? @ 0x00007f7519d19ac3 21. ? @ 0x00007f7519dab850 2025.10.23 23:45:07.589847 [ 2813 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.681861 [ 2818 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.764428 [ 2853 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.900373 [ 2969 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.901468 [ 2967 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.903211 [ 2961 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:07.972846 [ 2976 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.055358 [ 3022 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.142034 [ 3039 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.143395 [ 3446 ] {} DDLWorker(test_1_repl_01111_5): Error on initialization of test_1_repl_01111_5: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.414144 [ 18922 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.592020 [ 3075 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.684852 [ 3065 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.766925 [ 3084 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.780210 [ 17481 ] {d916eace-23be-4b44-ae42-34339ce8d4a9} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:ef54b34b-d6b5-4cea-9f0a-8fc5035d46a4', current host ID: '793cd66ee8bf:9000:23d9701c-9f1f-47d6-b866-4485d3171498'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59284) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_14 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:08.794525 [ 17481 ] {d916eace-23be-4b44-ae42-34339ce8d4a9} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:ef54b34b-d6b5-4cea-9f0a-8fc5035d46a4', current host ID: '793cd66ee8bf:9000:23d9701c-9f1f-47d6-b866-4485d3171498'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:08.902858 [ 3074 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.903731 [ 3095 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.905201 [ 3096 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:08.976554 [ 3093 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.057571 [ 3100 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.144098 [ 3098 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.191079 [ 18099 ] {d372934d-34dc-47be-8c3d-2abc7ee09dfc} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59322) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_13.tab update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:09.291830 [ 18099 ] {d372934d-34dc-47be-8c3d-2abc7ee09dfc} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:09.619155 [ 3278 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.678981 [ 18099 ] {f8f06bec-1d77-4f89-8554-78fc0d5db220} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:5d2e7274-04d9-4691-be37-919b3a5f1822'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59338) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_13 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:09.683045 [ 18099 ] {f8f06bec-1d77-4f89-8554-78fc0d5db220} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:5d2e7274-04d9-4691-be37-919b3a5f1822'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:09.694484 [ 3283 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.779015 [ 2813 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.910127 [ 2857 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.912098 [ 2869 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.912779 [ 2856 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:09.978908 [ 2874 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.061155 [ 2859 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.146534 [ 2865 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.294873 [ 3389 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {ea299d1d-6a64-4384-9014-89925bfc5db4::202510_1_149_30}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.621481 [ 2877 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.696902 [ 2908 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.768510 [ 18099 ] {d02060e2-2c8c-4f2a-8b61-283133f8e5c7} executeQuery: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59392) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_13.rmt_19556_27547_16328 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:10.784734 [ 2892 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.786606 [ 18099 ] {d02060e2-2c8c-4f2a-8b61-283133f8e5c7} TCPHandler: Code: 36. DB::Exception: Macro 'uuid' and empty arguments of ReplicatedMergeTree are supported only for ON CLUSTER queries with Atomic database engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Common/Macros.cpp:112: DB::Macros::expand(String const&, DB::Macros::MacroExpansionInfo&) const @ 0x000000001adf6cda 5. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&)::$_0::operator()(DB::ASTLiteral*, DB::ASTLiteral*) const @ 0x000000002cbbd2e9 6. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:0: DB::extractZooKeeperPathAndReplicaNameFromEngineArgs(DB::ASTCreateQuery const&, DB::StorageID const&, String const&, absl::InlinedVector, 7ul, std::allocator>>&, DB::LoadingStrictnessLevel, std::shared_ptr const&, String&, String&, DB::RenamingRestrictions&) @ 0x000000002cbadd46 7. ./build_docker/./src/Storages/MergeTree/registerStorageMergeTree.cpp:536: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb2067 8. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 9. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 12. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 13. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 15. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 16. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 18. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 19. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:45:10.808292 [ 24921 ] {9d8103d3-d546-4457-b2e0-279c16211cbd} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:7d45b4e4-2273-4c3c-91cd-3af80ee3ef8c', current host ID: '793cd66ee8bf:9000:d1f1c424-b97b-4f09-b289-ee97cc8905a5'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59380) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_9 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '0', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:10.834950 [ 24921 ] {9d8103d3-d546-4457-b2e0-279c16211cbd} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 0 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:7d45b4e4-2273-4c3c-91cd-3af80ee3ef8c', current host ID: '793cd66ee8bf:9000:d1f1c424-b97b-4f09-b289-ee97cc8905a5'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:10.912502 [ 2909 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.914565 [ 2905 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.915266 [ 2794 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:10.983728 [ 2878 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.063542 [ 2895 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.154423 [ 2954 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.626077 [ 3052 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.703250 [ 3097 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.791320 [ 3104 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.914827 [ 3109 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.916861 [ 3109 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.917441 [ 3112 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.989664 [ 3073 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:11.991881 [ 4049 ] {24d0214c-b818-47de-9a3a-8df46d94947c} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:cd4b4631-1732-46e4-bec0-13177faa8d7b'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59458) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_4 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:12.005666 [ 4049 ] {24d0214c-b818-47de-9a3a-8df46d94947c} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:cd4b4631-1732-46e4-bec0-13177faa8d7b'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:12.021096 [ 24921 ] {056bea7d-5e5e-4d8b-b1d3-1262bbdd11dc} executeQuery: Code: 47. DB::Exception: Missing columns: 'n' while processing query: 'SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')', required columns: 'n': While processing (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3: While processing n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3): While processing _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3), 'Int32'): While processing if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3), 'Int32'), n): While processing _CAST(if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3), 'Int32'), n), 'Int32'). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59454) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_11.rmt_25754_10294_9366 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000299b56b6 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:649: 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 @ 0x0000000029395dfb 6. ./build_docker/./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) @ 0x000000002938c51e 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:212: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029386230 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:259: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000294f05b8 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000294ecbff 10. ./contrib/llvm-project/libcxx/include/vector:432: DB::getQueryInterpreter(DB::ASTSubquery const&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e655e 11. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:0: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295dec84 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295de6bd 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 16. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 17. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 20. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 21. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 22. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 23. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 24. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x00000000299bbc53 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1507: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299bebf9 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b8a22 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2162 31. ./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) @ 0x00000000295a6166 2025.10.23 23:45:12.040551 [ 24921 ] {056bea7d-5e5e-4d8b-b1d3-1262bbdd11dc} TCPHandler: Code: 47. DB::Exception: Missing columns: 'n' while processing query: 'SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')', required columns: 'n': While processing (SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3: While processing n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3): While processing _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3), 'Int32'): While processing if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3), 'Int32'), n): While processing _CAST(if(1, _CAST(n + ((SELECT max(n) FROM merge(REGEXP('test_1.*'), '.*')) AS _subquery3), 'Int32'), n), 'Int32'). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1280: DB::TreeRewriterResult::collectUsedColumns(std::shared_ptr const&, bool, bool) @ 0x00000000299ac57c 4. ./build_docker/./src/Interpreters/TreeRewriter.cpp:0: DB::TreeRewriter::analyzeSelect(std::shared_ptr&, DB::TreeRewriterResult&&, DB::SelectQueryOptions const&, std::vector> const&, std::vector> const&, std::shared_ptr) const @ 0x00000000299b56b6 5. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:649: 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 @ 0x0000000029395dfb 6. ./build_docker/./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) @ 0x000000002938c51e 7. ./build_docker/./src/Interpreters/InterpreterSelectQuery.cpp:212: DB::InterpreterSelectQuery::InterpreterSelectQuery(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x0000000029386230 8. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:259: DB::InterpreterSelectWithUnionQuery::buildCurrentChildInterpreter(std::shared_ptr const&, std::vector> const&) @ 0x00000000294f05b8 9. ./build_docker/./src/Interpreters/InterpreterSelectWithUnionQuery.cpp:0: DB::InterpreterSelectWithUnionQuery::InterpreterSelectWithUnionQuery(std::shared_ptr const&, std::shared_ptr, DB::SelectQueryOptions const&, std::vector> const&) @ 0x00000000294ecbff 10. ./contrib/llvm-project/libcxx/include/vector:432: DB::getQueryInterpreter(DB::ASTSubquery const&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e655e 11. ./build_docker/./src/Interpreters/ExecuteScalarSubqueriesVisitor.cpp:0: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTSubquery const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295dec84 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:815: DB::ExecuteScalarSubqueriesMatcher::visit(std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295de6bd 13. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 14. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 15. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 16. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 17. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 18. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 19. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 20. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 21. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 22. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 23. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 24. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::ExecuteScalarSubqueriesMatcher::visit(DB::ASTFunction const&, std::shared_ptr&, DB::ExecuteScalarSubqueriesMatcher::Data&) @ 0x00000000295e5b16 25. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000295dd5bf 26. ./src/Interpreters/InDepthNodeVisitor.h:64: void DB::InDepthNodeVisitor>::visitChildren(std::shared_ptr&) @ 0x00000000295dd849 27. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:1551: DB::(anonymous namespace)::executeScalarSubqueries(std::shared_ptr&, std::shared_ptr, unsigned long, std::map, std::allocator>>&, std::map, std::allocator>>&, bool, bool) @ 0x00000000299bbc53 28. ./build_docker/./src/Interpreters/TreeRewriter.cpp:1507: DB::TreeRewriter::analyze(std::shared_ptr&, DB::NamesAndTypesList const&, std::shared_ptr, std::shared_ptr const&, bool, bool, bool, bool) const @ 0x00000000299bebf9 29. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:1115: DB::MutationsInterpreter::prepareMutationStages(std::vector>&, bool) @ 0x00000000295b8a22 30. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:0: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2162 31. ./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) @ 0x00000000295a6166 2025.10.23 23:45:12.066366 [ 3115 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.157872 [ 3111 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.631701 [ 3113 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.706108 [ 3130 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.793575 [ 3133 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.802397 [ 4049 ] {903d6f90-64c9-49db-bc06-ecfab67b384f} executeQuery: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59496) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_11.rmt_10909_18759_23208 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:45:12.814419 [ 4049 ] {903d6f90-64c9-49db-bc06-ecfab67b384f} TCPHandler: Code: 571. DB::Exception: ZooKeeper session expired or replication stopped, try again. (DATABASE_REPLICATION_FAILED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:327: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db5eea 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:45:12.917553 [ 3128 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.919418 [ 3108 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.920160 [ 3142 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:12.994061 [ 3140 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.072082 [ 3107 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.166208 [ 3146 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.448905 [ 15589 ] {a384c68d-0305-4c33-8623-31d6a3b3834f} executeQuery: Code: 81. DB::Exception: Database test_1_repl_01111_5 does not exist. Maybe you meant test_1_repl_01111_1?. (UNKNOWN_DATABASE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59406) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_1_repl_01111_5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000286c1eb3 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1211: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbcf46 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:13.475934 [ 15589 ] {a384c68d-0305-4c33-8623-31d6a3b3834f} TCPHandler: Code: 81. DB::Exception: Database test_1_repl_01111_5 does not exist. Maybe you meant test_1_repl_01111_1?. (UNKNOWN_DATABASE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:666: DB::DatabaseCatalog::getDatabase(String const&) const @ 0x00000000286c1eb3 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1211: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbcf46 6. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:13.634070 [ 3158 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.666481 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.708793 [ 3164 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.796256 [ 3176 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.919927 [ 3185 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.921655 [ 3153 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.922131 [ 3184 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:13.935328 [ 24921 ] {f55fdb71-3e71-4f56-a096-b941e06f94a4} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59484) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: drop table if exists view_00840;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:45:13.950696 [ 24921 ] {f55fdb71-3e71-4f56-a096-b941e06f94a4} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage View. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeToTable(DB::ASTDropQuery&) @ 0x00000000291fbfe5 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa6e8 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:45:13.967047 [ 17481 ] {2b529db7-c455-4beb-aeac-44f51054856c} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59538) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_13.tab update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:13.977861 [ 17481 ] {2b529db7-c455-4beb-aeac-44f51054856c} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:13.996539 [ 3118 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.074464 [ 3138 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.173888 [ 3168 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.636713 [ 3194 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.711771 [ 3200 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.855307 [ 3207 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.922219 [ 3208 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.924433 [ 3211 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.924551 [ 3214 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:14.999253 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.077144 [ 3219 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.176298 [ 3206 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.207919 [ 17481 ] {e7b074fa-2dc5-42ff-bab0-80d99664e5be} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:d7e59120-f85e-4c4a-90ac-b3b8b5755bdb', current host ID: '793cd66ee8bf:9000:1573b3be-2e61-4356-b11f-6aeeca6f9a3e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45766) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_5 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:15.240286 [ 17481 ] {e7b074fa-2dc5-42ff-bab0-80d99664e5be} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:d7e59120-f85e-4c4a-90ac-b3b8b5755bdb', current host ID: '793cd66ee8bf:9000:1573b3be-2e61-4356-b11f-6aeeca6f9a3e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:15.690731 [ 3223 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.714906 [ 3231 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.858304 [ 3235 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.870504 [ 24921 ] {6acc6bc4-31c5-487a-8a5e-1bcf4ec44bc8} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45786) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_13.ids update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:15.870927 [ 4281 ] {} DDLWorker(test_1_repl_01111_1): Unexpected error (1 times in a row), will try to restart main thread: Code: 341. DB::Exception: Replication was stopped. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:390: DB::DatabaseReplicatedDDLWorker::initAndCheckTask(String const&, String&, std::shared_ptr const&) @ 0x0000000027db990b 5. ./build_docker/./src/Interpreters/DDLWorker.cpp:415: DB::DDLWorker::scheduleTasks(bool) @ 0x0000000028688ca1 6. ./build_docker/./src/Interpreters/DDLWorker.cpp:0: DB::DDLWorker::runMainThread() @ 0x000000002867d888 7. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.902230 [ 24921 ] {6acc6bc4-31c5-487a-8a5e-1bcf4ec44bc8} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:15.925044 [ 3213 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.927377 [ 3155 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:15.928157 [ 3213 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.002924 [ 3238 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.081772 [ 3232 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.180072 [ 3221 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.437340 [ 24921 ] {9d5cee8e-0911-4d25-8f1f-3be88d7a9ce3} executeQuery: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:d7e59120-f85e-4c4a-90ac-b3b8b5755bdb', current host ID: '793cd66ee8bf:9000:195528e2-964a-46fc-a5b2-d9255a890c2e'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45804) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_5 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '0')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:16.485316 [ 24921 ] {9d5cee8e-0911-4d25-8f1f-3be88d7a9ce3} TCPHandler: Code: 253. DB::Exception: Replica 0 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:d7e59120-f85e-4c4a-90ac-b3b8b5755bdb', current host ID: '793cd66ee8bf:9000:195528e2-964a-46fc-a5b2-d9255a890c2e'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:16.693072 [ 3265 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.716975 [ 3245 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.861517 [ 3277 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.927862 [ 3267 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.931661 [ 3263 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:16.932539 [ 3282 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.009613 [ 3275 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.084400 [ 3250 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.188815 [ 3270 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.700811 [ 2779 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.719797 [ 3256 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.752937 [ 15589 ] {f0b1fde3-4007-465a-b173-15fbb05d100c} executeQuery: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45844) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: system sync database replica test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:17.763632 [ 15589 ] {f0b1fde3-4007-465a-b173-15fbb05d100c} TCPHandler: Code: 36. DB::Exception: SYSTEM SYNC DATABASE REPLICA query is intended to work only with Replicated engine. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:1224: DB::InterpreterSystemQuery::syncReplicatedDatabase(DB::ASTSystemQuery&) @ 0x0000000029bbd563 5. ./build_docker/./src/Interpreters/InterpreterSystemQuery.cpp:694: DB::InterpreterSystemQuery::execute() @ 0x0000000029ba5dca 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:17.786201 [ 4049 ] {e62fdbea-022d-424b-8aff-72ef00e1aa5f} executeQuery: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45858) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_1.distributed_01099_b update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:17.805122 [ 4049 ] {e62fdbea-022d-424b-8aff-72ef00e1aa5f} TCPHandler: Code: 48. DB::Exception: Table engine Distributed doesn't support mutations. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::checkMutationIsPossible(DB::MutationCommands const&, DB::Settings const&) const @ 0x000000002b68c618 4. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180462 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 6. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 7. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 9. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 10. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 12. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 13. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 2025.10.23 23:45:17.863664 [ 2803 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.931500 [ 2772 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.934527 [ 3283 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:17.939012 [ 2792 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.012245 [ 2798 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.111623 [ 3280 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.191862 [ 2789 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.703678 [ 2805 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.722888 [ 2776 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.746197 [ 25324 ] {dae3381c-6035-4d90-bf13-bb50693c40c0} executeQuery: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:bf3dad98-1bdf-4e17-83bf-49f4a62a8219'. (REPLICA_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45898) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: create database if not exists test_1_repl_01111_2 engine=Replicated('/test/01111/01111_create_drop_replicated_db_stress_test_1', '1', '1')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:18.771092 [ 25324 ] {dae3381c-6035-4d90-bf13-bb50693c40c0} TCPHandler: Code: 253. DB::Exception: Replica 1 of shard 1 of replicated database at /test/01111/01111_create_drop_replicated_db_stress_test_1 already exists. Replica host ID: '793cd66ee8bf:9000:c16374b6-0e53-4eca-a292-6f9544987344', current host ID: '793cd66ee8bf:9000:bf3dad98-1bdf-4e17-83bf-49f4a62a8219'. (REPLICA_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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&) @ 0x0000000027d96475 4. ./build_docker/./src/Databases/DatabaseReplicated.cpp:458: DB::DatabaseReplicated::tryConnectToZooKeeperAndInitDatabase(DB::LoadingStrictnessLevel) @ 0x0000000027d4e2b4 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::DatabaseReplicated::beforeLoadingMetadata(std::shared_ptr, DB::LoadingStrictnessLevel) @ 0x0000000027d56651 6. ./build_docker/./src/Databases/TablesLoader.cpp:0: DB::TablesLoader::loadTablesAsync(std::unordered_set, std::hash>, std::equal_to>, std::allocator>>) @ 0x00000000291e9ba2 7. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919ab87 8. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:18.865999 [ 2807 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.933546 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.933744 [ 3271 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.941498 [ 2817 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:18.941876 [ 2808 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.014804 [ 2814 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.114468 [ 2821 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.194341 [ 2823 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.507506 [ 17479 ] {c924130b-4bc9-4d26-910d-4d3eb1abdd93} executeQuery: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 540.83 MiB (attempt to allocate chunk of 133698400 bytes), maximum: 476.84 MiB. (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59980) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (in query: -- for WITH TOTALS previous groups should be kept. select key, groupArray(repeat('a', 200)), count() from data_01513 group by key with totals format Null settings optimize_aggregation_in_order=1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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>&&) @ 0x000000001ae006bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfee3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000cf712be 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000cf70fdf 10. ./src/Common/Arena.h:340: DB::(anonymous namespace)::GroupArrayGeneralImpl>::merge(char*, char const*, DB::Arena*) const @ 0x0000000022990725 11. ./build_docker/./src/Columns/ColumnAggregateFunction.cpp:513: DB::ColumnAggregateFunction::insertMergeFrom(char const*) @ 0x000000002ab27d8a 12. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:270: DB::TotalsHavingTransform::addToTotals(DB::Chunk const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002db39e15 13. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:0: DB::TotalsHavingTransform::transform(DB::Chunk&) @ 0x000000002db37eed 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49e43f 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d33fff9 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:45:19.707509 [ 2832 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.718380 [ 17479 ] {c924130b-4bc9-4d26-910d-4d3eb1abdd93} TCPHandler: Code: 241. DB::Exception: Memory limit (for query) exceeded: would use 540.83 MiB (attempt to allocate chunk of 133698400 bytes), maximum: 476.84 MiB. (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: 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>&&) @ 0x000000001ae006bd 4. ./build_docker/./src/Common/MemoryTracker.cpp:343: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfee3f 5. ./build_docker/./src/Common/MemoryTracker.cpp:0: MemoryTracker::allocImpl(long, bool, MemoryTracker*, double) @ 0x000000001adfe7d7 6. ./build_docker/./src/Common/CurrentMemoryTracker.cpp:59: CurrentMemoryTracker::alloc(long) @ 0x000000001ad3689d 7. ./build_docker/./src/Common/Allocator.cpp:151: Allocator::alloc(unsigned long, unsigned long) @ 0x000000001ad32b85 8. DB::Arena::addMemoryChunk(unsigned long) @ 0x000000000cf712be 9. DB::Arena::alignedAlloc(unsigned long, unsigned long) @ 0x000000000cf70fdf 10. ./src/Common/Arena.h:340: DB::(anonymous namespace)::GroupArrayGeneralImpl>::merge(char*, char const*, DB::Arena*) const @ 0x0000000022990725 11. ./build_docker/./src/Columns/ColumnAggregateFunction.cpp:513: DB::ColumnAggregateFunction::insertMergeFrom(char const*) @ 0x000000002ab27d8a 12. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:270: DB::TotalsHavingTransform::addToTotals(DB::Chunk const&, DB::PODArray, 63ul, 64ul> const*) @ 0x000000002db39e15 13. ./build_docker/./src/Processors/Transforms/TotalsHavingTransform.cpp:0: DB::TotalsHavingTransform::transform(DB::Chunk&) @ 0x000000002db37eed 14. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49e43f 15. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d33fff9 16. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 17. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 18. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 20. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:45:19.733725 [ 2819 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.746582 [ 24921 ] {e84c4155-a336-4336-bf98-77d1607e8d28} executeQuery: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45946) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: alter table test_13.data2 update n = n + (select max(n) from merge(REGEXP('test_1.*'), '.*')) where 1 settings allow_nondeterministic_mutations=1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:19.772033 [ 24921 ] {e84c4155-a336-4336-bf98-77d1607e8d28} TCPHandler: Code: 8. DB::Exception: Column n is updated but not requested to read. (THERE_IS_NO_COLUMN), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:588: DB::MutationsInterpreter::prepare(bool) @ 0x00000000295b2886 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MutationsInterpreter::MutationsInterpreter(DB::MutationsInterpreter::Source, std::shared_ptr, DB::MutationCommands, std::vector>, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a6166 6. ./build_docker/./src/Interpreters/MutationsInterpreter.cpp:377: DB::MutationsInterpreter::MutationsInterpreter(std::shared_ptr, std::shared_ptr, DB::MutationCommands, std::shared_ptr, DB::MutationsInterpreter::Settings) @ 0x00000000295a4855 7. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:228: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x00000000291805e8 8. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:19.868795 [ 2834 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.935970 [ 2840 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.944120 [ 2818 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.946111 [ 2849 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:19.948740 [ 18922 ] {58f11984-87d4-4d13-9b1e-94eab345d447} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36276) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (in query: DROP DATABASE IF EXISTS test_zsgrrkpc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:45:19.953744 [ 18922 ] {58f11984-87d4-4d13-9b1e-94eab345d447} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.017443 [ 2839 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.097391 [ 24921 ] {f0221b81-711e-40eb-8a0b-15c2f414da6b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:36288) (comment: 01513_optimize_aggregation_in_order_memory_long.sql) (in query: DROP DATABASE IF EXISTS test_zsgrrkpc ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:45:20.103815 [ 24921 ] {f0221b81-711e-40eb-8a0b-15c2f414da6b} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.117186 [ 2843 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.199766 [ 2847 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.710858 [ 2862 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.736519 [ 2841 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.891627 [ 2851 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.939223 [ 2876 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.947851 [ 2879 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:20.949078 [ 2848 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.020354 [ 2882 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.123226 [ 2911 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.157806 [ 2933 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.212440 [ 2948 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.714757 [ 2910 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.740196 [ 3003 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.894313 [ 3007 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.980463 [ 3013 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.980996 [ 3016 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:21.985953 [ 3022 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.026200 [ 3025 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.125580 [ 3027 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.160738 [ 2981 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.215343 [ 3009 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.743934 [ 3012 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.811793 [ 3024 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.897676 [ 3015 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.983769 [ 3037 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.984287 [ 3032 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:22.991261 [ 3028 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.032257 [ 3020 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.128140 [ 3038 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.163625 [ 3002 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.306250 [ 3030 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.753234 [ 3050 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.814479 [ 3023 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.901064 [ 3057 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.986136 [ 3070 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.987101 [ 3045 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:23.994165 [ 3062 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.035238 [ 3036 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.121968 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.130957 [ 3067 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.172277 [ 3071 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.313294 [ 3080 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.757029 [ 3094 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.818789 [ 3091 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.974786 [ 3064 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.990632 [ 3082 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.991777 [ 3026 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:24.997057 [ 3078 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.038700 [ 3089 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.134241 [ 3081 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.175878 [ 3087 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.317138 [ 3095 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.761191 [ 3099 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.822132 [ 3029 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.906897 [ 24921 ] {6d51e52a-423a-4a5b-a9aa-f4dc6b536d38} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43628) (comment: 00840_long_concurrent_select_and_drop_deadlock.sh) (in query: select * from view_00840 order by table), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:25.916653 [ 24921 ] {6d51e52a-423a-4a5b-a9aa-f4dc6b536d38} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=729). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:25.977231 [ 2975 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.994712 [ 3112 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.999031 [ 3109 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:25.999655 [ 3102 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.041417 [ 3073 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.142341 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.178806 [ 3044 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.320406 [ 3105 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.825336 [ 3133 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.855147 [ 3144 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.979990 [ 3135 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:26.997537 [ 3125 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.001894 [ 3134 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.002533 [ 3140 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.044588 [ 3137 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.145933 [ 3146 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.182378 [ 3141 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.323750 [ 3103 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.829416 [ 3164 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.859081 [ 3136 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:27.982770 [ 3188 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.000094 [ 3162 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.095557 [ 3184 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.096555 [ 3180 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.096733 [ 3118 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.149222 [ 3173 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.185433 [ 3138 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.326652 [ 3175 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.831907 [ 3200 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.862077 [ 3199 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:28.985085 [ 3198 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.003614 [ 3207 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.098623 [ 3211 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.099324 [ 3214 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.100436 [ 3204 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.151799 [ 3177 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.188490 [ 3190 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.200941 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.329511 [ 3210 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.834473 [ 3238 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.865341 [ 3237 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:29.988378 [ 3248 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.102582 [ 3254 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.102744 [ 3252 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.102883 [ 3259 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.154591 [ 3227 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.157795 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.191186 [ 3265 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.332324 [ 3258 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.837655 [ 3253 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.868477 [ 3261 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:30.993133 [ 2779 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.106130 [ 3273 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.106924 [ 2796 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.107568 [ 2790 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.157426 [ 2772 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.160330 [ 3283 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.194322 [ 2806 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.335575 [ 3280 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.440282 [ 4049 ] {274662b0-9a1c-4d3e-a16f-d88656edf8f8} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=2). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:51756) (comment: 03093_reading_bug_with_parallel_replicas.sql) (in query: SELECT `__table1`.`a` AS `a` FROM `test_hgkf4ov4`.`t2` AS `__table1` GROUP BY `__table1`.`a`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.444193 [ 4049 ] {274662b0-9a1c-4d3e-a16f-d88656edf8f8} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=2). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:252: DB::InterpreterSelectQueryAnalyzer::buildQueryPipeline() @ 0x000000002942d9ff 14. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:436: DB::InterpreterSelectQueryAnalyzer::execute() @ 0x000000002942d267 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.708215 [ 25390 ] {a514b0b3-2e37-4d7c-859a-33ec31ae88ba} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:39234) (comment: 03093_reading_bug_with_parallel_replicas.sql) (in query: SELECT `__table1`.`a` AS `a` FROM `test_hgkf4ov4`.`t2` AS `__table1` GROUP BY `__table1`.`a`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.715186 [ 25390 ] {a514b0b3-2e37-4d7c-859a-33ec31ae88ba} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.740143 [ 15589 ] {9385ee59-2f12-4395-aeb3-36394b9f9550} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43656) (comment: 03093_reading_bug_with_parallel_replicas.sql) (in query: select a from t2 group by a format Null;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.747979 [ 4049 ] {} ServerErrorHandler: Code: 210. DB::NetException: Connection reset by peer, while reading from socket (peer: [::ffff:127.0.0.1]:51756, local: [::ffff:127.0.0.2]:9000). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:83: DB::ReadBufferFromPocoSocketBase::socketReceiveBytesImpl(char*, unsigned long) @ 0x000000001b0ba0a2 4. ./build_docker/./src/IO/ReadBufferFromPocoSocket.cpp:107: DB::ReadBufferFromPocoSocketBase::nextImpl() @ 0x000000001b0babe4 5. ./build_docker/./src/IO/ReadBufferFromPocoSocketChunked.cpp:103: DB::ReadBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf20db6 6. DB::ReadBuffer::next() @ 0x000000000b52caeb 7. ./build_docker/./src/Server/TCPHandler.cpp:383: DB::TCPHandler::runImpl() @ 0x000000002d191773 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.752337 [ 15589 ] {9385ee59-2f12-4395-aeb3-36394b9f9550} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=3, jobs=3). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.795508 [ 17481 ] {3f46221d-021e-4670-bb2c-17394a4aa22a} executeQuery: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:58936). (NETWORK_ERROR) (version 24.8.14.10542.altinitytest (altinity build)) (from [::ffff:127.0.0.1]:58936) (comment: 03093_reading_bug_with_parallel_replicas.sql) (in query: SELECT `__table1`.`a` AS `a` FROM `test_hgkf4ov4`.`t2` AS `__table1` GROUP BY `__table1`.`a`), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1ad70b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a8129 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.804031 [ 17481 ] {3f46221d-021e-4670-bb2c-17394a4aa22a} 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]:58936). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:169: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0bee02 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendLogData(DB::Block const&) @ 0x000000002d1c638b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::sendLogs() @ 0x000000002d1aa2f9 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d1930a2 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.821155 [ 17481 ] {3f46221d-021e-4670-bb2c-17394a4aa22a} TCPHandler: Code: 210. DB::NetException: Connection reset by peer, while writing to socket ([::ffff:127.0.0.3]:9000 -> [::ffff:127.0.0.1]:58936). (NETWORK_ERROR), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. ./contrib/llvm-project/libcxx/include/string:1499: DB::NetException::NetException(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&) @ 0x000000001b0bbabf 3. ./build_docker/./src/IO/WriteBufferFromPocoSocket.cpp:158: DB::WriteBufferFromPocoSocket::nextImpl() @ 0x000000001b0beb62 4. ./build_docker/./src/IO/WriteBufferFromPocoSocketChunked.cpp:201: DB::WriteBufferFromPocoSocketChunked::nextImpl() @ 0x000000002cf263b7 5. ./src/IO/WriteBuffer.h:66: DB::TCPHandler::sendData(DB::Block const&) @ 0x000000002d1ad70b 6. ./contrib/llvm-project/libcxx/include/__hash_table:1473: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a8129 7. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.835383 [ 17481 ] {3f46221d-021e-4670-bb2c-17394a4aa22a} TCPHandler: Client has gone away. 2025.10.23 23:45:31.840425 [ 2799 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.871571 [ 2781 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:31.992178 [ 24921 ] {fc83f83b-a9c1-495b-843a-83085294dacd} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:53756) (comment: 03093_reading_bug_with_parallel_replicas.sql) (in query: DROP DATABASE IF EXISTS test_hgkf4ov4 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:45:31.996958 [ 2797 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.006297 [ 24921 ] {fc83f83b-a9c1-495b-843a-83085294dacd} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.109208 [ 2811 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.109866 [ 3271 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.110348 [ 2815 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.168017 [ 9657 ] {} test_hgkf4ov4.t2 (e2a0ec56-853c-41c7-8687-c2e4ce661282): dropAllData: got exception removing parts from disk, removing successfully removed parts from memory. 2025.10.23 23:45:32.242450 [ 9657 ] {} DatabaseCatalog: Cannot drop table test_hgkf4ov4.t2 (e2a0ec56-853c-41c7-8687-c2e4ce661282). Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c48f325 8. ./contrib/llvm-project/libcxx/include/vector:547: DB::MergeTreeData::clearPartsFromFilesystem(std::vector, std::allocator>> const&, bool, std::unordered_set, std::equal_to, std::allocator>*) @ 0x000000002c48d66e 9. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:0: DB::MergeTreeData::dropAllData() @ 0x000000002c4991b9 10. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: DB::DatabaseCatalog::dropTableFinally(DB::DatabaseCatalog::TableMarkedAsDropped const&) @ 0x00000000286d2908 11. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:0: void std::__function::__policy_invoker::__call_impl, std::allocator>>)::$_0, void ()>>(std::__function::__policy_storage const*) @ 0x00000000286e5424 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x00000000263a8145 13. ./contrib/llvm-project/libcxx/include/future:0: std::packaged_task::operator()() @ 0x000000001bba74cc 14. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 15. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 16. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 17. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.256296 [ 2784 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.257375 [ 2814 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.257577 [ 2831 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.338637 [ 3281 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.874798 [ 2832 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:32.941961 [ 2837 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.005775 [ 2834 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.120350 [ 2828 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.120949 [ 2850 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.121378 [ 2852 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.260156 [ 2830 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.262174 [ 2863 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.263494 [ 2830 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.341940 [ 2856 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.877984 [ 2846 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:33.945339 [ 2868 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.009403 [ 2851 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.123183 [ 2871 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.123859 [ 2874 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.124808 [ 2864 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.263396 [ 2848 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.265353 [ 2887 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.266282 [ 2881 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.279960 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.345231 [ 2859 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.881510 [ 2890 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:34.954898 [ 2900 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.012692 [ 2791 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.126428 [ 2903 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.128670 [ 2892 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.128924 [ 2899 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.265813 [ 2794 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.273286 [ 2878 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.273419 [ 2914 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.348294 [ 2904 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.884825 [ 2922 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:35.958683 [ 2925 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.015466 [ 2902 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.130460 [ 2895 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.132276 [ 2927 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.133083 [ 2906 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.269137 [ 2939 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.276485 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.276794 [ 2933 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.351615 [ 2929 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.888383 [ 2940 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:36.962153 [ 2934 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.019434 [ 2944 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.133389 [ 2959 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.135289 [ 2949 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.136658 [ 2959 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.271718 [ 2958 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.279333 [ 2960 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.280006 [ 2966 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.354244 [ 2967 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.892005 [ 2974 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:37.965718 [ 2987 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.022401 [ 2983 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.136591 [ 2980 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.138188 [ 2988 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.180571 [ 2984 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.276387 [ 2985 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.283644 [ 2994 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.284622 [ 2977 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.428504 [ 2971 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.523063 [ 25324 ] {1c6fc8e2-e90e-4c64-98e8-dc30f2837962} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43432) (comment: 02252_reset_non_existing_setting.sql) (in query: ALTER TABLE most_ordinary_mt RESET SETTING ttl;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3476: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4aa65f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180212 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:38.538430 [ 25324 ] {1c6fc8e2-e90e-4c64-98e8-dc30f2837962} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'ttl' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3476: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4aa65f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180212 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:38.636627 [ 25324 ] {11c14f77-495b-4cdd-a1ce-83acedbdba24} executeQuery: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43432) (comment: 02252_reset_non_existing_setting.sql) (in query: ALTER TABLE most_ordinary_mt RESET SETTING allow_remote_fs_zero_copy_replication, xxx;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3476: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4aa65f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180212 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:38.640872 [ 25324 ] {11c14f77-495b-4cdd-a1ce-83acedbdba24} TCPHandler: Code: 36. DB::Exception: Cannot reset setting 'xxx' because it doesn't exist for MergeTree engines family. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/MergeTree/MergeTreeData.cpp:3476: DB::MergeTreeData::checkAlterIsPossible(DB::AlterCommands const&, std::shared_ptr) const @ 0x000000002c4aa65f 5. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:0: DB::InterpreterAlterQuery::executeToTable(DB::ASTAlterQuery const&) @ 0x0000000029180212 6. ./build_docker/./src/Interpreters/InterpreterAlterQuery.cpp:74: DB::InterpreterAlterQuery::execute() @ 0x000000002917c3f1 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:38.899038 [ 3007 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:38.969164 [ 3000 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.024936 [ 3013 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.140139 [ 3027 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.141274 [ 2981 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.183797 [ 3009 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.280425 [ 3033 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.287460 [ 3005 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.287600 [ 3014 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.401237 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.431539 [ 3012 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.904066 [ 3032 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:39.985355 [ 2894 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.028046 [ 3034 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.142997 [ 3030 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.144008 [ 3043 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.187089 [ 3053 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.283580 [ 3047 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.290976 [ 3046 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.291107 [ 2997 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.434397 [ 3023 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.907871 [ 3011 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:40.998439 [ 3036 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.030836 [ 3051 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.145855 [ 3080 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.146977 [ 3059 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.190578 [ 3060 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.288999 [ 3065 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.296809 [ 3075 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.301772 [ 3084 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.437341 [ 3079 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:41.911608 [ 3087 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.005706 [ 3093 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.034058 [ 3096 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.148885 [ 3098 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.149458 [ 3092 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.193568 [ 3029 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.292528 [ 3101 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.302505 [ 3112 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.305410 [ 3109 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.440891 [ 3111 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:42.923226 [ 3131 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.013010 [ 3144 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.037440 [ 3128 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.154818 [ 3135 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.155558 [ 3125 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.197292 [ 3134 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.295705 [ 3143 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.305739 [ 3146 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.308813 [ 3107 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.443962 [ 3145 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:43.928493 [ 3178 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.015848 [ 3185 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.040192 [ 3153 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.157958 [ 3184 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.158757 [ 3180 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.200348 [ 3187 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.378486 [ 3189 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.378633 [ 3193 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.378760 [ 3191 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.446420 [ 3200 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.624131 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:44.766710 [ 4049 ] {b1678f10-665c-445b-9499-e39c040d2cce} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43452) (comment: 02286_parallel_final.sh) (in query: explain pipeline select * from tbl_8parts_2granules_rnd final settings max_threads = 16, do_not_merge_across_partitions_select_final = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:513: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002920f762 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x000000002920a43f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:45:44.814079 [ 4049 ] {b1678f10-665c-445b-9499-e39c040d2cce} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=2, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af86f93 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c663da0 7. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1745: 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) @ 0x000000002de541bd 8. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:1459: DB::ReadFromMergeTree::selectRangesToRead(std::vector, std::allocator>>, bool) const @ 0x000000002de51d0f 9. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:0: DB::ReadFromMergeTree::getAnalysisResult() const @ 0x000000002de5d985 10. ./build_docker/./src/Processors/QueryPlan/ReadFromMergeTree.cpp:2045: DB::ReadFromMergeTree::initializePipeline(DB::QueryPipelineBuilder&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de6068c 11. ./build_docker/./src/Processors/QueryPlan/ISourceStep.cpp:24: DB::ISourceStep::updatePipeline(std::vector>, std::allocator>>>, DB::BuildQueryPipelineSettings const&) @ 0x000000002ddd5cbc 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::QueryPlan::buildQueryPipeline(DB::QueryPlanOptimizationSettings const&, DB::BuildQueryPipelineSettings const&) @ 0x000000002de1ba9e 13. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:513: DB::InterpreterExplainQuery::executeImpl() @ 0x000000002920f762 14. ./build_docker/./src/Interpreters/InterpreterExplainQuery.cpp:0: DB::InterpreterExplainQuery::execute() @ 0x000000002920a43f 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:45:44.933857 [ 3198 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.023831 [ 3211 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.042961 [ 3214 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.160870 [ 3190 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.161552 [ 3219 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.203748 [ 3220 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.382181 [ 3152 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.382764 [ 3151 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.383527 [ 3206 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.449309 [ 3218 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:45.937167 [ 3230 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.027572 [ 3213 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.046585 [ 3239 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.163597 [ 3233 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.165082 [ 3241 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.211488 [ 3221 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.386400 [ 3247 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.388523 [ 3259 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.391631 [ 3236 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.484266 [ 25390 ] {e9c96841-7ab7-47d5-88c4-eabc8a714e5a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=729). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43444) (comment: 00294_shard_enums.sql) (in query: select * from enums_copy;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:46.489669 [ 25390 ] {e9c96841-7ab7-47d5-88c4-eabc8a714e5a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=808, jobs=729). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8b357 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af7f331 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af80453 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d3859ad 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:138: DB::PullingAsyncPipelineExecutor::pull(DB::Block&, unsigned long) @ 0x000000002d3865ff 8. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::processOrdinaryQuery() @ 0x000000002d1a771b 9. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d192bea 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:46.531772 [ 3265 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:46.940587 [ 3268 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.031712 [ 3263 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.049586 [ 3269 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.166167 [ 3250 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.167599 [ 2775 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.213870 [ 3257 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.389642 [ 3147 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.392126 [ 2779 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.394840 [ 2779 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.534599 [ 3273 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:47.944014 [ 2792 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.038096 [ 3183 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.052634 [ 3280 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.168836 [ 2788 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.170497 [ 2789 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.221708 [ 2795 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.230223 [ 25390 ] {b32d078f-1e21-4b50-9099-25e16ab8855f} 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.10542.altinitytest (altinity build)) (from [::1]:59330) (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 = 1602, min_bytes_for_wide_part = 722507326, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 526273223, compact_parts_max_granules_to_buffer = 198, compact_parts_merge_max_bytes_to_prefetch_part = 3431192, merge_max_block_size = 17297, old_parts_lifetime = 168., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 81, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2610846, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 61864, primary_key_compress_block_size = 14162), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:785: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000291ad5b8 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b8e00 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:48.232723 [ 25390 ] {b32d078f-1e21-4b50-9099-25e16ab8855f} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:785: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000291ad5b8 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b8e00 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:48.392770 [ 2781 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.395402 [ 2776 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.398008 [ 2780 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.480523 [ 25390 ] {a9a14f06-58fb-4c7a-874e-f9b9d8723472} executeQuery: Code: 127. DB::Exception: Please use index type 'full_text' instead of 'inverted'. (ILLEGAL_INDEX) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59330) (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 = 1602, min_bytes_for_wide_part = 722507326, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 526273223, compact_parts_max_granules_to_buffer = 198, compact_parts_merge_max_bytes_to_prefetch_part = 3431192, merge_max_block_size = 17297, old_parts_lifetime = 168., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 81, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2610846, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 61864, primary_key_compress_block_size = 14162), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:789: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000291ad518 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b8e00 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:48.482665 [ 25390 ] {a9a14f06-58fb-4c7a-874e-f9b9d8723472} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:789: DB::InterpreterCreateQuery::getTablePropertiesAndNormalizeCreateQuery(DB::ASTCreateQuery&, DB::LoadingStrictnessLevel) const @ 0x00000000291ad518 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b8e00 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:48.537591 [ 2812 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:48.638536 [ 25390 ] {efc768f3-4803-473b-99b5-ecefb40fdfb7} executeQuery: Code: 57. DB::Exception: Table test_13.tab already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59330) (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 = 1602, min_bytes_for_wide_part = 722507326, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 128, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 526273223, compact_parts_max_granules_to_buffer = 198, compact_parts_merge_max_bytes_to_prefetch_part = 3431192, merge_max_block_size = 17297, old_parts_lifetime = 168., prefer_fetch_merged_part_size_threshold = 10737418240, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 81, min_merge_bytes_to_use_direct_io = 10737418240, index_granularity_bytes = 2610846, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 61864, primary_key_compress_block_size = 14162), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:48.641774 [ 25390 ] {efc768f3-4803-473b-99b5-ecefb40fdfb7} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:45:48.947749 [ 2811 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.041631 [ 2815 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.055377 [ 2808 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.171847 [ 2831 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.173080 [ 2816 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.224586 [ 2821 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.395765 [ 2810 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.398052 [ 2833 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.400546 [ 2787 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.540837 [ 2829 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.733111 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:49.953079 [ 2838 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.045959 [ 2818 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.058748 [ 2839 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.175739 [ 2847 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.227157 [ 2863 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.244368 [ 2855 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.453666 [ 2854 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.453899 [ 2867 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.454766 [ 2866 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.483809 [ 25390 ] {63841c84-92f6-43ad-bbf1-505df717f91d} executeQuery: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59334) (comment: 03214_json_typed_dynamic_path.sql) (in query: optimize table test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000002cbe1474 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:1637: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000002cbec116 9. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be902e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:45:50.491724 [ 25390 ] {63841c84-92f6-43ad-bbf1-505df717f91d} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000002cbe1474 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:1637: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000002cbec116 9. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be902e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:45:50.543576 [ 2870 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:50.956439 [ 2879 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.050374 [ 2881 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.063347 [ 2861 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.178887 [ 2882 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.230765 [ 2873 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.247492 [ 2888 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.456874 [ 2889 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.457189 [ 2900 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.458367 [ 2791 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.546435 [ 2903 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:51.959592 [ 2845 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.053449 [ 2917 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.066340 [ 2918 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.181819 [ 2922 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.234491 [ 2925 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.323434 [ 2902 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.460624 [ 2939 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.461471 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.461933 [ 2936 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.549592 [ 2802 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:52.963161 [ 2946 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.056708 [ 2940 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.069392 [ 2942 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.185341 [ 2934 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.238009 [ 2950 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.326628 [ 2935 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.463707 [ 2955 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.464650 [ 2972 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.465147 [ 2943 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.553117 [ 2958 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:53.653663 [ 25390 ] {} TCPHandler: Code: 452. DB::Exception: Setting allow_experimental_object_type should not be changed. (SETTING_CONSTRAINT_VIOLATION), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception>&>(int, FormatStringHelperImpl>&>::type>, std::basic_string_view>&) @ 0x0000000011c2c6b4 4. ./build_docker/./src/Access/SettingsConstraints.cpp:332: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f8646e 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/remove_if.h:32: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85912 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./build_docker/./src/Server/TCPHandler.cpp:2034: DB::TCPHandler::receiveQuery() @ 0x000000002d1bdf4d 10. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::receivePacket() @ 0x000000002d1a3f82 11. ./build_docker/./src/Server/TCPHandler.cpp:0: DB::TCPHandler::runImpl() @ 0x000000002d191801 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:53.966931 [ 2969 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.063882 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.072364 [ 2973 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.191864 [ 2979 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.241334 [ 2987 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.297346 [ 25390 ] {70fd488b-740e-4c89-9bd8-f52ebcf7c3b4} executeQuery: Code: 60. DB::Exception: Table test_13.ghdata does not exist. Maybe you meant test_13.data?. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45660) (comment: 01825_type_json_ghdata.sh) (in query: INSERT INTO ghdata FORMAT JSONAsObject), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:54.301769 [ 25390 ] {70fd488b-740e-4c89-9bd8-f52ebcf7c3b4} TCPHandler: Code: 60. DB::Exception: Table test_13.ghdata does not exist. Maybe you meant test_13.data?. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type, std::type_identity::type, std::type_identity::type>, String&&, String&&, String&&, String&&) @ 0x000000000ac6e006 4. ./build_docker/./src/Databases/IDatabase.cpp:39: DB::IDatabase::getTable(String const&, std::shared_ptr) const @ 0x0000000027ddc60a 5. ./contrib/llvm-project/libcxx/include/__utility/swap.h:37: DB::DatabaseCatalog::getTableImpl(DB::StorageID const&, std::shared_ptr, std::optional*) const @ 0x00000000286b9c4b 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:801: DB::DatabaseCatalog::getTable(DB::StorageID const&, std::shared_ptr) const @ 0x00000000286c5d57 7. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:0: DB::InterpreterInsertQuery::getTable(DB::ASTInsertQuery&) @ 0x000000002935a1b6 8. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:748: DB::InterpreterInsertQuery::execute() @ 0x00000000293696c9 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:45:54.330058 [ 2783 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.467600 [ 2980 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.467988 [ 2988 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.468992 [ 2999 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.556349 [ 2995 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.649568 [ 4049 ] {f3a4cc1e-9e7a-429a-a0ef-84006a014304} executeQuery: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:59348) (comment: 02286_parallel_final.sh) (in query: optimize table tbl_8parts_5granules_rnd final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000002cbe1474 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000002cbebf39 9. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be902e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:45:54.658745 [ 4049 ] {f3a4cc1e-9e7a-429a-a0ef-84006a014304} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000002cbe1474 8. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000002cbebf39 9. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be902e 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:45:54.925035 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:54.970836 [ 2991 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.023130 [ 25390 ] {8fd5aa4c-7d1b-45ac-87b3-53bef0ef5ea0} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45674) (comment: 01825_type_json_ghdata.sh) (in query: SELECT count() FROM ghdata WHERE NOT ignore(*)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:45:55.035950 [ 25390 ] {8fd5aa4c-7d1b-45ac-87b3-53bef0ef5ea0} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT count() FROM ghdata WHERE NOT ignore(*). (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:45:55.067305 [ 3007 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.075136 [ 3008 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.195197 [ 3013 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.244823 [ 3025 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.333783 [ 3017 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.471561 [ 3005 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.471605 [ 3018 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.472886 [ 3012 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.559773 [ 2998 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:55.974618 [ 3020 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.077373 [ 3002 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.077724 [ 3040 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.198552 [ 3030 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.248436 [ 3053 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.337644 [ 3042 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.474740 [ 3055 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.475636 [ 3057 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.476202 [ 3049 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.562891 [ 3062 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:56.978150 [ 3060 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.080656 [ 3077 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.081555 [ 3048 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.201674 [ 3086 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.252080 [ 3083 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.340327 [ 3085 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.478633 [ 3064 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.479694 [ 3082 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.480560 [ 3026 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.530960 [ 25390 ] {1af8d87a-ef55-4d54-add3-df2fde421455} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45712) (comment: 01825_type_json_ghdata.sh) (in query: SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:45:57.535667 [ 25390 ] {1af8d87a-ef55-4d54-add3-df2fde421455} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.repo.name, count() AS stars FROM ghdata WHERE data.type = 'WatchEvent' GROUP BY data.repo.name ORDER BY stars DESC, data.repo.name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:45:57.566138 [ 3074 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:57.989781 [ 3099 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.083897 [ 2975 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.085886 [ 3109 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.133168 [ 25390 ] {1a19c9b4-a190-4168-a70e-fc27c475eaed} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45722) (comment: 01825_type_json_ghdata.sh) (in query: SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name LIMIT 5), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:45:58.154841 [ 25390 ] {1a19c9b4-a190-4168-a70e-fc27c475eaed} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT data.payload.commits.author.name AS name, count() AS c FROM ghdata ARRAY JOIN data.payload.commits.author.name GROUP BY name ORDER BY c DESC, name ASC LIMIT 5. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:45:58.208163 [ 3120 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.255196 [ 3111 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.343519 [ 3088 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.483759 [ 3121 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.484641 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.484898 [ 3124 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.493866 [ 3119 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.569166 [ 3122 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:58.910777 [ 25390 ] {17ef8f1e-a86b-4690-a7d8-0ae764d1eec4} executeQuery: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata. (UNKNOWN_TABLE) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45736) (comment: 01825_type_json_ghdata.sh) (in query: SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:45:58.921591 [ 25390 ] {17ef8f1e-a86b-4690-a7d8-0ae764d1eec4} TCPHandler: Code: 60. DB::Exception: Unknown table expression identifier 'ghdata' in scope SELECT max(data.payload.pull_request.assignees.size0) FROM ghdata. (UNKNOWN_TABLE), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String&&) @ 0x000000000c44e97a 4. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:4229: DB::QueryAnalyzer::initializeQueryJoinTreeNode(std::shared_ptr&, DB::IdentifierResolveScope&) @ 0x00000000283c3050 5. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:5436: DB::QueryAnalyzer::resolveQuery(std::shared_ptr const&, DB::IdentifierResolveScope&) @ 0x0000000028365678 6. ./build_docker/./src/Analyzer/Resolve/QueryAnalyzer.cpp:0: DB::QueryAnalyzer::resolve(std::shared_ptr&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000028363aa4 7. ./build_docker/./src/Analyzer/Resolve/QueryAnalysisPass.cpp:19: DB::QueryAnalysisPass::run(std::shared_ptr&, std::shared_ptr) @ 0x00000000283628ad 8. ./build_docker/./src/Analyzer/QueryTreePassManager.cpp:0: DB::QueryTreePassManager::run(std::shared_ptr) @ 0x000000002922a74c 9. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:0: DB::(anonymous namespace)::buildQueryTreeAndRunPasses(std::shared_ptr const&, DB::SelectQueryOptions const&, std::shared_ptr const&, std::shared_ptr const&) @ 0x000000002942bb93 10. ./build_docker/./src/Interpreters/InterpreterSelectQueryAnalyzer.cpp:160: DB::InterpreterSelectQueryAnalyzer::InterpreterSelectQueryAnalyzer(std::shared_ptr const&, std::shared_ptr const&, DB::SelectQueryOptions const&, std::vector> const&) @ 0x000000002942636f 11. ./contrib/llvm-project/libcxx/include/vector:432: std::__unique_if::__unique_single std::make_unique[abi:v15007]&, std::shared_ptr const&, DB::SelectQueryOptions const&>(std::shared_ptr&, std::shared_ptr const&, DB::SelectQueryOptions const&) @ 0x000000002942e7dd 12. ./build_docker/./src/Interpreters/InterpreterFactory.cpp:0: DB::InterpreterFactory::get(std::shared_ptr&, std::shared_ptr, DB::SelectQueryOptions const&) @ 0x000000002935359b 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43a5b 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:45:58.993185 [ 3142 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.086620 [ 3140 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.088565 [ 3143 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.211487 [ 3107 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.258337 [ 3141 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.346199 [ 3148 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.486894 [ 3170 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.489559 [ 3160 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.496598 [ 3159 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:45:59.571875 [ 3136 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.004883 [ 3118 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.090038 [ 3181 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.091558 [ 3187 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.112865 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.215016 [ 3175 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.261817 [ 3182 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.349769 [ 3139 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.492421 [ 3172 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.491460 [ 3200 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.500734 [ 3199 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:00.520084 [ 25390 ] {0b4cf24a-3cbe-4eeb-b5a8-78ac538e50ad} executeQuery: Code: 57. DB::Exception: Table test_13.mt_compact already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45748) (comment: 01055_compact_parts_1.sql) (in query: create table mt_compact (a Int, s String) engine = MergeTree order by a partition by a settings index_granularity_bytes = 0;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:46:00.523153 [ 25390 ] {0b4cf24a-3cbe-4eeb-b5a8-78ac538e50ad} TCPHandler: Code: 57. DB::Exception: Table test_13.mt_compact already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:46:00.574674 [ 3195 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.008206 [ 3190 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.093901 [ 3222 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.095583 [ 3149 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.216121 [ 25390 ] {c5b782e0-ef77-4c8e-8e56-32b73270bd94} executeQuery: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45750) (comment: 02889_print_pretty_type_names.sql) (in query: create table test (a Tuple(b String, c Tuple(d Nullable(UInt64), e Array(UInt32), f Array(Tuple(g String, h Map(String, Array(Tuple(i String, j UInt64))))), k Date), l Nullable(String))) engine=Memory;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:46:01.218590 [ 3151 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.221054 [ 25390 ] {c5b782e0-ef77-4c8e-8e56-32b73270bd94} TCPHandler: Code: 57. DB::Exception: Table test_13.test already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:46:01.265551 [ 3206 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.353055 [ 3218 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.495534 [ 3157 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.501127 [ 3231 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.503368 [ 3234 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:01.578196 [ 3230 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.011972 [ 3233 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.096940 [ 3242 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.097999 [ 3221 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.221951 [ 3247 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.268416 [ 3259 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.355774 [ 3254 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.498246 [ 3266 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.504194 [ 3268 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.505732 [ 3277 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:02.581218 [ 3269 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.015983 [ 3257 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.099285 [ 3261 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.099904 [ 3279 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.225053 [ 3256 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.271672 [ 2779 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.359622 [ 2790 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.501799 [ 2803 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.507565 [ 3249 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.514336 [ 2772 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:03.584023 [ 2798 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.018822 [ 2812 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.101687 [ 2811 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.102250 [ 3271 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.104027 [ 17481 ] {9a3c5725-5c0f-4378-8d1f-cb564a86a2bb} executeQuery: Code: 48. DB::Exception: DELETE query is not supported for table test_13.t_projections_lwd as it has projections. User should drop all the projections manually before running the query. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45772) (comment: 02792_drop_projection_lwd.sql) (in query: -- LWD does not work, as expected DELETE FROM t_projections_lwd WHERE a = 1;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000029c53950 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:46:04.108415 [ 17481 ] {9a3c5725-5c0f-4378-8d1f-cb564a86a2bb} TCPHandler: Code: 48. DB::Exception: DELETE query is not supported for table test_13.t_projections_lwd as it has projections. User should drop all the projections manually before running the query. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/InterpreterDeleteQuery.cpp:128: DB::InterpreterDeleteQuery::execute() @ 0x0000000029c53950 5. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 6. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 8. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 9. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 11. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 12. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:46:04.227252 [ 2784 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.274292 [ 2814 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.362734 [ 3281 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.507595 [ 2787 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.511056 [ 2825 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.520035 [ 2829 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:04.587977 [ 2835 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.021596 [ 2840 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.105558 [ 2828 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.106400 [ 2850 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.206887 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.230057 [ 2847 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.271594 [ 2855 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286d17dc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286d20a6 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.277080 [ 2857 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.290460 [ 25390 ] {fd0a0a8a-3c6f-4bb6-ac14-05705a797063} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45770) (comment: 02286_parallel_final.sh) (in query: optimize table tbl_8parts_2granules_seq final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000002cbe1474 21. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000002cbebf39 22. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be902e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:46:05.324387 [ 25390 ] {fd0a0a8a-3c6f-4bb6-ac14-05705a797063} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000002cbe1474 21. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000002cbebf39 22. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be902e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:46:05.373364 [ 2854 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.512608 [ 2862 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.514200 [ 2870 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.522954 [ 2841 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:05.591530 [ 2851 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.025075 [ 2879 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.109401 [ 2881 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.109777 [ 2887 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.232741 [ 2865 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.279782 [ 2896 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.376322 [ 2888 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.516075 [ 2791 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.517427 [ 2897 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.526229 [ 2903 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:06.595080 [ 2909 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.029129 [ 2886 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.113100 [ 2901 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.114410 [ 2914 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.235312 [ 2925 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.282367 [ 2916 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.379064 [ 2906 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.519493 [ 2928 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.522189 [ 2926 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.529398 [ 2937 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.598502 [ 2885 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:07.750133 [ 17481 ] {66e6c93d-4097-43a2-b825-5d6d16dbbe5e} executeQuery: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43970) (in query: select _path,_file from file('nonexist.txt', 'CSV', 'val1 char')), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002b7ac8c2 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:856: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000294767a2 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1771: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002946a23d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029439226 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000029432a7b 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002942ddd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43d9e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:46:07.753313 [ 17481 ] {66e6c93d-4097-43a2-b825-5d6d16dbbe5e} TCPHandler: Code: 107. DB::Exception: File /var/lib/clickhouse/user_files/nonexist.txt doesn't exist. (FILE_DOESNT_EXIST), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageFile.cpp:1604: DB::StorageFile::read(DB::QueryPlan&, std::vector> const&, std::shared_ptr const&, DB::SelectQueryInfo&, std::shared_ptr, DB::QueryProcessingStage::Enum, unsigned long, unsigned long) @ 0x000000002b7ac8c2 5. ./build_docker/./src/Planner/PlannerJoinTree.cpp:856: DB::(anonymous namespace)::buildQueryPlanForTableExpression(std::shared_ptr, DB::SelectQueryInfo const&, DB::SelectQueryOptions const&, std::shared_ptr&, bool, bool) @ 0x00000000294767a2 6. ./build_docker/./src/Planner/PlannerJoinTree.cpp:1771: DB::buildJoinTreeQueryPlan(std::shared_ptr const&, DB::SelectQueryInfo const&, DB::SelectQueryOptions&, std::unordered_set, std::equal_to, std::allocator> const&, std::shared_ptr&) @ 0x000000002946a23d 7. ./build_docker/./src/Planner/Planner.cpp:0: DB::Planner::buildPlanForQueryNode() @ 0x0000000029439226 8. ./build_docker/./src/Planner/Planner.cpp:1254: DB::Planner::buildQueryPlanIfNeeded() @ 0x0000000029432a7b 9. ./src/Planner/Planner.h:44: DB::InterpreterSelectQueryAnalyzer::getQueryPlan() @ 0x000000002942ddd2 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1182: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b43d9e 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:46:07.993405 [ 3392 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_305_315_2}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.032269 [ 2934 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.116391 [ 2944 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.118255 [ 2954 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.239411 [ 2949 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.285708 [ 2955 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.381668 [ 2964 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.567118 [ 2969 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.568166 [ 2962 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.575924 [ 2965 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:08.601095 [ 2978 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.034938 [ 2995 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.119145 [ 2984 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.121674 [ 2985 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.242133 [ 2992 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.288013 [ 3010 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.384644 [ 3003 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.551888 [ 25390 ] {b5bf5e7e-90d6-4d26-a70a-f74ffa3a60eb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:43956) (comment: 02286_parallel_final.sh) (in query: optimize table tbl_8parts_3granules_seq final;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000002cbe1474 21. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000002cbebf39 22. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be902e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:46:09.566973 [ 25390 ] {b5bf5e7e-90d6-4d26-a70a-f74ffa3a60eb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./src/Storages/MergeTree/MergePlainMergeTreeTask.h:104: DB::StorageMergeTree::merge(bool, String const&, bool, bool, std::vector> const&, bool, std::shared_ptr const&, PreformattedMessage&, bool) @ 0x000000002cbe1474 21. ./build_docker/./src/Storages/StorageMergeTree.cpp:1609: DB::StorageMergeTree::optimize(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr const&, bool, bool, std::vector> const&, bool, std::shared_ptr) @ 0x000000002cbebf39 22. ./build_docker/./src/Interpreters/InterpreterOptimizeQuery.cpp:84: DB::InterpreterOptimizeQuery::execute() @ 0x0000000029be902e 23. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 24. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 25. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 26. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 27. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 28. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 29. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 30. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 31. asan_thread_start(void*) @ 0x000000000aa47059 2025.10.23 23:46:09.570622 [ 3001 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.574760 [ 3007 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.581110 [ 3000 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:09.604227 [ 3004 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.045609 [ 3033 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.123684 [ 3018 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.125553 [ 3005 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.245408 [ 2998 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.315472 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.361744 [ 3024 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.392273 [ 3015 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.589323 [ 2894 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.590398 [ 3020 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.590643 [ 3028 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:10.607805 [ 3034 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.049425 [ 3056 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.127261 [ 3055 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.129125 [ 3057 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.149237 [ 25390 ] {f118088b-c2a1-45fd-b2a5-ee05805c65e0} 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.10542.altinitytest (altinity build)) (from [::1]:44004) (comment: 02731_replace_partition_from_temporary_table.sql) (in query: CREATE TABLE rdst (`p` UInt64, `k` String, `d` UInt64) ENGINE = ReplicatedMergeTree('/clickhouse/tables/{database}/test_alter_attach_00626_rdst', 'r1') PARTITION BY p ORDER BY k SETTINGS index_granularity = 61374, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 68, min_bytes_for_full_part_storage = 462411379, compact_parts_max_bytes_to_buffer = 368785195, compact_parts_max_granules_to_buffer = 40, compact_parts_merge_max_bytes_to_prefetch_part = 14351305, merge_max_block_size = 4412, old_parts_lifetime = 10., prefer_fetch_merged_part_size_threshold = 5721495780, vertical_merge_algorithm_min_rows_to_activate = 1000000, vertical_merge_algorithm_min_columns_to_activate = 100, min_merge_bytes_to_use_direct_io = 1, index_granularity_bytes = 4891044, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 63123, primary_key_compress_block_size = 93341), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c470388 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000002ba27574 9. ./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&) @ 0x000000002cbc16db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb809f 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:46:11.189897 [ 25390 ] {f118088b-c2a1-45fd-b2a5-ee05805c65e0} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c470388 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000002ba27574 9. ./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&) @ 0x000000002cbc16db 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb809f 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 16. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 17. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 18. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 19. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 20. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 21. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 22. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007f7519d19ac3 25. ? @ 0x00007f7519dab850 2025.10.23 23:46:11.248696 [ 3045 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.398241 [ 3061 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.398808 [ 3080 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.593044 [ 3077 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.594180 [ 3048 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.594525 [ 3069 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:11.611928 [ 3065 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.054008 [ 3081 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.135461 [ 3087 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.135744 [ 3093 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.252353 [ 3072 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.403408 [ 3100 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.403941 [ 3098 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.595549 [ 3101 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.597548 [ 2975 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.598387 [ 3109 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:12.614730 [ 3112 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.044509 [ 25390 ] {6f3219a0-1d77-4df8-99af-c8dc3a22ff33} executeQuery: Code: 47. DB::Exception: Unknown qualified identifier: insert_select_src: While processing insert_select_src.* EXCEPT (middle_a, middle_b). (UNKNOWN_IDENTIFIER) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44030) (comment: 01470_test_insert_select_asterisk.sql) (in query: INSERT INTO insert_select_dst(insert_select_src.* EXCEPT (middle_a, middle_b)) SELECT * FROM insert_select_src;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/TranslateQualifiedNamesVisitor.cpp:172: DB::TranslateQualifiedNamesMatcher::visit(DB::ASTQualifiedAsterisk const&, std::shared_ptr const&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000029a5f33d 5. ./build_docker/./src/Interpreters/TranslateQualifiedNamesVisitor.cpp:0: DB::TranslateQualifiedNamesMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000029a5c2c3 6. ./build_docker/./src/Interpreters/TranslateQualifiedNamesVisitor.cpp:0: DB::TranslateQualifiedNamesMatcher::visit(std::shared_ptr&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000029a5b19b 7. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000299ced1f 8. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::processColumnTransformers(String const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000029bd4b8d 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:174: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000002935d310 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44816 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:46:13.047503 [ 25390 ] {6f3219a0-1d77-4df8-99af-c8dc3a22ff33} TCPHandler: Code: 47. DB::Exception: Unknown qualified identifier: insert_select_src: While processing insert_select_src.* EXCEPT (middle_a, middle_b). (UNKNOWN_IDENTIFIER), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. ./build_docker/./src/Interpreters/TranslateQualifiedNamesVisitor.cpp:172: DB::TranslateQualifiedNamesMatcher::visit(DB::ASTQualifiedAsterisk const&, std::shared_ptr const&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000029a5f33d 5. ./build_docker/./src/Interpreters/TranslateQualifiedNamesVisitor.cpp:0: DB::TranslateQualifiedNamesMatcher::visit(DB::ASTExpressionList&, std::shared_ptr const&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000029a5c2c3 6. ./build_docker/./src/Interpreters/TranslateQualifiedNamesVisitor.cpp:0: DB::TranslateQualifiedNamesMatcher::visit(std::shared_ptr&, DB::TranslateQualifiedNamesMatcher::Data&) @ 0x0000000029a5b19b 7. ./src/Interpreters/InDepthNodeVisitor.h:78: DB::InDepthNodeVisitor>::doVisit(std::shared_ptr&) @ 0x00000000299ced1f 8. ./src/Interpreters/InDepthNodeVisitor.h:64: DB::processColumnTransformers(String const&, std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr) @ 0x0000000029bd4b8d 9. ./build_docker/./src/Interpreters/InterpreterInsertQuery.cpp:174: DB::InterpreterInsertQuery::getInsertColumnNames() const @ 0x000000002935d310 10. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44816 11. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 12. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 13. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:46:13.057160 [ 3044 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.138303 [ 3121 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.139147 [ 3124 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.255522 [ 3122 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.406489 [ 3132 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.407775 [ 3129 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.600419 [ 3135 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.601429 [ 3134 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.603565 [ 3125 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:13.617827 [ 3140 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.062354 [ 3163 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.140933 [ 3170 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.141748 [ 3160 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.258218 [ 3156 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.409798 [ 3169 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.410774 [ 3178 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.603473 [ 3184 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.604369 [ 3180 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.606626 [ 3174 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:14.620817 [ 3118 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.065179 [ 3191 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.144344 [ 3200 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.144960 [ 3199 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.261398 [ 3209 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.414194 [ 3203 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.415491 [ 3190 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.422592 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/302/30276cea-66f1-4432-8136-bd499816db34/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.607022 [ 3218 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.607557 [ 3217 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.609108 [ 3226 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:15.623367 [ 3201 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.068407 [ 3239 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.071880 [ 25390 ] {70afc1da-2eaa-4f6d-86d0-ade26863fcf3} executeQuery: Code: 57. DB::Exception: Table test_13.ts already exists. (TABLE_ALREADY_EXISTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:44046) (comment: 02730_with_fill_by_sorting_prefix.sql) (in query: CREATE TABLE ts (`sensor_id` UInt64, `timestamp` UInt64, `value` Float64) ENGINE = MergeTree ORDER BY (sensor_id, timestamp) SETTINGS index_granularity = 20815, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 0., replace_long_file_name_to_hash = true, max_file_name_length = 102, min_bytes_for_full_part_storage = 536870912, compact_parts_max_bytes_to_buffer = 486805781, compact_parts_max_granules_to_buffer = 230, compact_parts_merge_max_bytes_to_prefetch_part = 32446729, merge_max_block_size = 4030, old_parts_lifetime = 43., 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 = 1507057190, index_granularity_bytes = 19324435, concurrent_part_removal_threshold = 100, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = false, marks_compress_block_size = 33585, primary_key_compress_block_size = 82338), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:46:16.074713 [ 25390 ] {70afc1da-2eaa-4f6d-86d0-ade26863fcf3} TCPHandler: Code: 57. DB::Exception: Table test_13.ts already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1617: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c947f 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 8. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 9. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 10. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 11. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 13. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 14. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 2025.10.23 23:46:16.146955 [ 3232 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.147647 [ 3233 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.264363 [ 3241 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.417736 [ 3248 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.418725 [ 3247 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.609901 [ 3251 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.610787 [ 3243 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.611965 [ 3245 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:16.626170 [ 3274 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.073714 [ 3275 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.150812 [ 3253 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.151907 [ 3270 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.267868 [ 3261 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.422369 [ 3147 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.506835 [ 3256 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.613452 [ 3273 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.614614 [ 2796 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.615439 [ 2790 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:17.629864 [ 2804 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.077221 [ 2782 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.154412 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.155031 [ 2776 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.271377 [ 2786 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.425351 [ 2812 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.510345 [ 2813 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.616473 [ 2815 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.621620 [ 2815 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.622483 [ 2784 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:18.634062 [ 2816 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.157399 [ 2819 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.158416 [ 2832 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.221995 [ 2820 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.274237 [ 2822 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.429046 [ 2818 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.513562 [ 2843 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.663256 [ 2847 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.664361 [ 2860 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.664954 [ 2863 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:19.666960 [ 2857 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.063147 [ 3389 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {855a1c57-459a-4184-97ab-17bc8cfce245::202510_1_176_35}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.160560 [ 2872 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.162506 [ 2851 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.225464 [ 2871 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.278708 [ 2874 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.432494 [ 2876 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.516469 [ 2859 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.539845 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.667334 [ 2896 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.667759 [ 2873 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.669025 [ 2898 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:20.670483 [ 2893 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.164327 [ 2877 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.167622 [ 2892 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.231256 [ 2880 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.281728 [ 2794 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.435735 [ 2886 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.519203 [ 2907 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.670681 [ 2922 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.671548 [ 2925 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.672709 [ 2911 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:21.677285 [ 2916 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.079131 [ 18099 ] {773fc894-5835-4658-b6f2-4da5634e6b44} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45768) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_1_repl_01111_1), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:46:22.106827 [ 18099 ] {773fc894-5835-4658-b6f2-4da5634e6b44} TCPHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:46:22.167592 [ 2936 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.170389 [ 2936 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.234086 [ 2937 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.284434 [ 2929 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.442226 [ 2946 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.525602 [ 2940 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.674696 [ 2950 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.675437 [ 2944 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.676106 [ 2954 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:22.688742 [ 2945 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.170567 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.175032 [ 2978 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.274909 [ 2956 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.287005 [ 2987 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.445107 [ 2980 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.529040 [ 2999 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.678735 [ 2994 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.679571 [ 2977 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.680460 [ 2976 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:23.691479 [ 3010 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.173231 [ 3025 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.185320 [ 3019 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.278073 [ 3012 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.290583 [ 3018 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.448456 [ 2998 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.532406 [ 3024 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.681175 [ 2894 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.681881 [ 3020 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.683217 [ 3028 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:24.697194 [ 3034 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.176232 [ 3050 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.188506 [ 3023 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.281236 [ 3045 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.293632 [ 3062 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.451320 [ 3036 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.535298 [ 3061 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.684460 [ 3068 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.684610 [ 3077 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.685507 [ 3048 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:25.699660 [ 3069 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.179184 [ 3082 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.183746 [ 25390 ] {7b64806f-cf7d-4ad7-a1e6-07634d3b843a} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=19). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33340) (comment: 02515_projections_with_totals.sql) (in query: SELECT x FROM t GROUP BY x WITH TOTALS;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:46:26.188225 [ 25390 ] {7b64806f-cf7d-4ad7-a1e6-07634d3b843a} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=19, jobs=19). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 2025.10.23 23:46:26.197812 [ 3026 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.283817 [ 3078 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.296512 [ 3081 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.375732 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.453942 [ 3104 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.537956 [ 3101 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.687333 [ 3102 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.748530 [ 3073 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.749305 [ 3114 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:26.750862 [ 3115 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.182204 [ 3123 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.200756 [ 3132 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.214824 [ 25390 ] {0bfcf943-21e6-4127-93d9-7aaa8bf1a115} 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.10542.altinitytest (altinity build)) (from [::1]:33352) (comment: 02006_client_test_hint_error_name.sql) (in query: select throwIf(1);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185a2e9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9df34e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49e43f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d33fff9 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:46:27.219220 [ 25390 ] {0bfcf943-21e6-4127-93d9-7aaa8bf1a115} TCPHandler: Code: 395. DB::Exception: Value passed to 'throwIf' function is non-zero: while executing 'FUNCTION throwIf(1_UInt8 :: 1) -> throwIf(1_UInt8) UInt8 : 2'. (FUNCTION_THROW_IF_VALUE_IS_NON_ZERO), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String&&) @ 0x000000000aad8b34 4. DB::(anonymous namespace)::FunctionThrowIf::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x00000000185a2e9c 5. DB::FunctionToExecutableFunctionAdaptor::executeImpl(std::vector> const&, std::shared_ptr const&, unsigned long) const @ 0x000000000aacd135 6. DB::IExecutableFunction::executeWithoutLowCardinalityColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd0e5b 7. DB::IExecutableFunction::executeWithoutSparseColumns(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd265c 8. DB::IExecutableFunction::execute(std::vector> const&, std::shared_ptr const&, unsigned long, bool) const @ 0x000000000ccd6030 9. ./contrib/boost/boost/smart_ptr/intrusive_ptr.hpp:117: DB::ExpressionActions::execute(DB::Block&, unsigned long&, bool, bool) const @ 0x0000000028707f9d 10. ./build_docker/./src/Processors/Transforms/ExpressionTransform.cpp:0: DB::ExpressionTransform::transform(DB::Chunk&) @ 0x000000002d9df34e 11. ./contrib/llvm-project/libcxx/include/__utility/swap.h:35: DB::ISimpleTransform::transform(DB::Chunk&, DB::Chunk&) @ 0x000000001b49e43f 12. ./build_docker/./src/Processors/ISimpleTransform.cpp:99: DB::ISimpleTransform::work() @ 0x000000002d33fff9 13. ./build_docker/./src/Processors/Executors/ExecutionThreadContext.cpp:0: DB::ExecutionThreadContext::executeTask() @ 0x000000002d37f78e 14. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:273: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d366571 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364f1c 16. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 17. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 18. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 19. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 20. asan_thread_start(void*) @ 0x000000000aa47059 21. ? @ 0x00007f7519d19ac3 22. ? @ 0x00007f7519dab850 2025.10.23 23:46:27.286835 [ 3131 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.299849 [ 3126 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.456712 [ 3108 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.541062 [ 3142 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.690469 [ 3140 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.752150 [ 3146 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.753263 [ 3141 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:27.755823 [ 3107 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.185099 [ 3171 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.203414 [ 3167 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.289503 [ 3176 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.303867 [ 3162 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.492175 [ 3180 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.552312 [ 3173 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.638945 [ 25390 ] {135a2d4e-d5be-4a2b-87d3-8c88cba124bb} 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.10542.altinitytest (altinity build)) (from [::1]:33362) (comment: 00632_aggregation_window_funnel.sql) (in query: select 4 = windowFunnel(10000)(timestamp, event = 1000, event = 1001, event = 1002, event = 1008) from funnel_test;), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:46:28.649617 [ 25390 ] {135a2d4e-d5be-4a2b-87d3-8c88cba124bb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:46:28.700284 [ 3181 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.755829 [ 3165 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.755941 [ 3175 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:28.758579 [ 3175 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.188334 [ 3195 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.206345 [ 3196 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.292565 [ 3202 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.306764 [ 3198 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.495077 [ 3203 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.558502 [ 3222 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.708587 [ 3226 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.759080 [ 3206 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.759806 [ 3223 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:29.761772 [ 3157 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.200758 [ 3232 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.209083 [ 3238 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.305742 [ 3246 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.310451 [ 3221 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.497527 [ 3259 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.561359 [ 3227 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.711868 [ 3252 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.762322 [ 3243 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.762994 [ 3245 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.764843 [ 3258 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:30.788139 [ 25390 ] {b7a35e05-fa25-4812-83b0-65f0c1023693} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:33374) (comment: 00737_decimal_group_by.sql) (in query: SELECT A, B_str, toString(cc) FROM (SELECT A, toString(B) AS B_str, SUM(C) AS cc FROM decimal GROUP BY A, B_str);), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:46:30.791152 [ 25390 ] {b7a35e05-fa25-4812-83b0-65f0c1023693} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:405: DB::PipelineExecutor::executeImpl(unsigned long, bool) @ 0x000000002d364e84 8. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:274: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364a1b 9. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 10. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 12. asan_thread_start(void*) @ 0x000000000aa47059 13. ? @ 0x00007f7519d19ac3 14. ? @ 0x00007f7519dab850 2025.10.23 23:46:31.203149 [ 2775 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.211684 [ 3257 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.308046 [ 3261 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.312863 [ 3279 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.500316 [ 3228 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.514405 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.564205 [ 2790 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.723097 [ 2772 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.765341 [ 3283 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.765932 [ 2792 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:31.768192 [ 2806 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.208771 [ 3212 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.215224 [ 2799 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.310999 [ 2781 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.318514 [ 2776 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.503578 [ 2793 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.567858 [ 2813 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.729247 [ 2811 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.768967 [ 2815 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.769825 [ 2784 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:32.771579 [ 2816 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.211674 [ 2832 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.218022 [ 2820 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.313602 [ 2838 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.321701 [ 2824 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.511902 [ 2839 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.571346 [ 2828 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.732522 [ 2850 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.772342 [ 2855 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.773050 [ 2860 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:33.774949 [ 2863 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.214650 [ 2841 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.220913 [ 2846 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.316656 [ 2851 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.326072 [ 2844 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.585166 [ 2876 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.595635 [ 2848 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.735630 [ 2859 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.775579 [ 2884 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.786731 [ 2882 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:34.787009 [ 2865 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.218526 [ 2853 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.226852 [ 2890 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.320183 [ 2903 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.328644 [ 2892 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.588427 [ 2908 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.598984 [ 2880 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.740719 [ 2794 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.779507 [ 2904 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.789663 [ 2878 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:35.790889 [ 2886 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.221069 [ 2924 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.229953 [ 2906 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.323109 [ 2909 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.360844 [ 2926 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.416122 [ 18922 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.591957 [ 2885 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.601871 [ 2932 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.619291 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.744836 [ 2940 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.833871 [ 2934 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.834839 [ 2941 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:36.835415 [ 2950 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.225304 [ 2958 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.232539 [ 2966 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.326004 [ 2960 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.395549 [ 2952 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.595349 [ 2978 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.605581 [ 2973 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.747947 [ 2956 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.837247 [ 2983 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.837991 [ 2986 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:37.839153 [ 2783 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.228652 [ 2977 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.235334 [ 2976 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.328594 [ 3006 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.401162 [ 3003 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.598867 [ 3001 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.608519 [ 3007 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.750816 [ 2993 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.840525 [ 3017 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.841228 [ 3025 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:38.842127 [ 3027 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.231492 [ 3041 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.238695 [ 3024 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.332345 [ 3021 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.404446 [ 2894 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.602709 [ 3038 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.612848 [ 3040 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.753944 [ 3042 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.844087 [ 3056 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.844630 [ 3054 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:39.845337 [ 3050 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.235190 [ 3049 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.242008 [ 3070 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.334773 [ 3051 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.407237 [ 3071 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.605771 [ 3059 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.615683 [ 3077 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.756837 [ 3052 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.855635 [ 3086 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.856672 [ 3083 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:40.856854 [ 3085 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.238420 [ 3078 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.245209 [ 3081 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.337332 [ 3100 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.409739 [ 3072 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.608322 [ 3099 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.617999 [ 2975 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.741058 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.759388 [ 3114 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.858391 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.859687 [ 3117 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:41.860260 [ 3111 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.242032 [ 3124 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.248450 [ 3119 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.341045 [ 3105 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.413769 [ 3127 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.611907 [ 3132 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.621104 [ 3129 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.762330 [ 3144 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.862087 [ 3135 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.870711 [ 3125 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:42.863446 [ 3134 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.245315 [ 3154 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.251692 [ 3150 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.345141 [ 3103 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.417758 [ 3170 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.616004 [ 3164 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.626810 [ 3136 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.766337 [ 3176 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.866297 [ 3188 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.874801 [ 3153 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:43.875456 [ 3174 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.248436 [ 3181 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.254700 [ 3182 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.348394 [ 3166 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.421126 [ 3191 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.619081 [ 3200 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.630038 [ 3172 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.769335 [ 3202 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.869636 [ 3198 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.878537 [ 3216 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:44.878945 [ 3207 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.251164 [ 3177 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.257191 [ 3222 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.351252 [ 3219 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.423933 [ 3226 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.633007 [ 3157 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.680346 [ 3223 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.772223 [ 3224 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.872307 [ 3235 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.881241 [ 3229 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:45.881396 [ 3155 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.253431 [ 3246 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.259599 [ 3221 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.354078 [ 3259 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.426918 [ 3236 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.457929 [ 25390 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.635587 [ 3254 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.682804 [ 3251 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.774912 [ 3266 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.814164 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.874789 [ 3274 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.903484 [ 3268 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:46.903949 [ 3264 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.256263 [ 2775 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.262700 [ 3257 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.357188 [ 3253 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.429542 [ 3279 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.638630 [ 2779 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.685491 [ 3228 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.778040 [ 2796 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.877664 [ 2803 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.958336 [ 3283 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:47.958228 [ 3249 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.259365 [ 3280 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.265580 [ 2789 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.360063 [ 2800 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.432376 [ 2795 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.641744 [ 3212 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.688410 [ 2780 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.785883 [ 2801 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.881260 [ 2793 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.961657 [ 2797 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:48.962339 [ 2813 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.262409 [ 2817 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.268327 [ 2815 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.363484 [ 2808 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.435903 [ 2814 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.645479 [ 2810 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.691825 [ 2829 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.789428 [ 2832 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.885004 [ 2822 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.964809 [ 2838 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:49.965472 [ 2824 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.265644 [ 2828 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.273916 [ 2828 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.368166 [ 2843 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.451700 [ 2847 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.649744 [ 2869 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.695789 [ 2830 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.793624 [ 2867 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.889330 [ 2841 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.968522 [ 2862 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:50.969452 [ 2870 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.269191 [ 2879 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.277756 [ 2848 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.371641 [ 2887 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.546153 [ 2882 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.653744 [ 2896 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.700075 [ 2893 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.796824 [ 2889 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.893190 [ 2853 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.972758 [ 2791 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:51.973311 [ 2903 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.047595 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.272466 [ 2908 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.280737 [ 2880 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.375322 [ 2905 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.556836 [ 2904 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.682338 [ 2901 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.703485 [ 2917 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.800525 [ 2918 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.898204 [ 2922 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.976488 [ 2916 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:52.985036 [ 2919 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.275633 [ 2802 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.284095 [ 2936 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.378609 [ 2928 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.559758 [ 2885 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.685442 [ 2912 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.706488 [ 2913 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.827020 [ 2946 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.901353 [ 2942 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.979945 [ 2941 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:53.989024 [ 2950 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.278620 [ 2949 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.287470 [ 2943 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.381931 [ 2947 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.564644 [ 2964 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.689123 [ 2967 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.709609 [ 2969 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.832395 [ 2978 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.905312 [ 2979 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.983924 [ 2974 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:54.993419 [ 2953 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.285286 [ 2986 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.290630 [ 2783 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.385025 [ 2980 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.568514 [ 2995 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.692355 [ 2985 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.712873 [ 2994 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.835150 [ 2992 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.908994 [ 2971 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.987833 [ 3003 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:55.996787 [ 2991 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.290298 [ 2951 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.294466 [ 2970 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.388358 [ 3004 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.572307 [ 3017 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.695721 [ 3027 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.716850 [ 2981 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.838669 [ 3013 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.913104 [ 2989 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:56.992237 [ 3033 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.001227 [ 3012 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.151151 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.301233 [ 3035 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.302437 [ 2998 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.392315 [ 3015 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.576394 [ 3037 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.699824 [ 3034 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.721290 [ 3002 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.842556 [ 3038 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.917304 [ 3043 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:57.996672 [ 3047 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.005786 [ 3046 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.306446 [ 3054 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.307067 [ 3050 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.397480 [ 3057 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.555276 [ 25390 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.580326 [ 3045 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.703910 [ 3011 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.725155 [ 3051 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.846057 [ 3061 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.921004 [ 3067 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:58.999783 [ 3059 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.008827 [ 3068 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.310356 [ 3075 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.311078 [ 3084 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.401286 [ 3083 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.584231 [ 3085 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.707234 [ 3064 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.728013 [ 3078 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.849223 [ 3066 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:46:59.924364 [ 3096 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.007168 [ 3100 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.015451 [ 3079 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.314516 [ 3072 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.315319 [ 3087 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.404645 [ 3029 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.587910 [ 3099 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.710747 [ 3112 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.731508 [ 3073 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.853084 [ 3114 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:00.927882 [ 3120 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.019041 [ 3111 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.056887 [ 3117 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.318541 [ 3088 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.319318 [ 3106 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.407914 [ 3105 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.592096 [ 3132 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.715164 [ 3130 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.734774 [ 3131 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.856828 [ 3133 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:01.931444 [ 3128 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.021661 [ 3135 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.064440 [ 3134 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.214710 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.322428 [ 3141 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.323401 [ 3107 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.412671 [ 3154 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.595901 [ 3170 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.719322 [ 3158 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.738436 [ 3156 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.860865 [ 3167 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:02.935550 [ 3164 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.025135 [ 3169 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.123428 [ 3176 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.325510 [ 3153 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.326001 [ 3174 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.415793 [ 3180 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.599693 [ 3184 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.741827 [ 3138 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.801399 [ 3168 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.864550 [ 3165 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:03.939028 [ 3187 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.028824 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.126763 [ 3197 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.328428 [ 3199 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.328927 [ 3200 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.418456 [ 3189 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.603243 [ 3216 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.745250 [ 3211 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.805006 [ 3204 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.868523 [ 3203 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:04.942756 [ 3177 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.032813 [ 3190 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.139895 [ 3149 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.339644 [ 3210 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.341036 [ 3218 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.420994 [ 3151 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.606552 [ 3205 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.748760 [ 3157 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.808459 [ 3223 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.887885 [ 3224 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:05.946391 [ 3230 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.036300 [ 3229 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.142925 [ 3155 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.343373 [ 3233 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.344759 [ 3232 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.424656 [ 3242 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.528782 [ 25390 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.610682 [ 3221 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.751909 [ 3247 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.812463 [ 3240 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.891930 [ 3248 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:06.950870 [ 3252 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.039862 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.146427 [ 3266 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.324182 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.348012 [ 3274 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.348906 [ 3268 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.428527 [ 3263 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.613609 [ 2774 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.755192 [ 3250 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.816084 [ 3257 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.895816 [ 3279 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:07.955157 [ 3260 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.042856 [ 3276 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.149494 [ 3272 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.353013 [ 2796 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.353356 [ 2790 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.432100 [ 2803 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.617124 [ 3283 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.758615 [ 3280 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.820126 [ 2778 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.912916 [ 2795 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:08.959225 [ 3212 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.046332 [ 2780 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.152713 [ 2801 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.356013 [ 2812 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.356587 [ 2797 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.435790 [ 2807 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.620202 [ 3271 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.762358 [ 2816 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.828909 [ 2827 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.916886 [ 2821 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:09.963030 [ 2823 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.049780 [ 2810 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.155977 [ 2829 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.359511 [ 2820 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.360601 [ 2836 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.439924 [ 2822 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.623867 [ 2818 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.768432 [ 2840 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.833499 [ 2849 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.920884 [ 2850 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:10.990558 [ 2847 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.053323 [ 2852 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.161332 [ 2855 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.363528 [ 2842 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.364364 [ 2869 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.443551 [ 2867 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.627253 [ 2846 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.772193 [ 2868 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.836829 [ 2872 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.924188 [ 2851 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:11.993431 [ 2876 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.057499 [ 2879 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.164670 [ 2881 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.369043 [ 2887 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.369812 [ 2859 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.421863 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.446152 [ 2884 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.630670 [ 2893 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.775760 [ 2891 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.839914 [ 2890 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:12.927355 [ 2903 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.000131 [ 2897 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.061307 [ 2892 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.168059 [ 2883 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.372526 [ 2908 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.373456 [ 2880 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.458190 [ 2904 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.634560 [ 2886 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.779133 [ 2914 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.847702 [ 2918 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:13.930628 [ 2923 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.003383 [ 2931 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.065119 [ 2925 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.172144 [ 2911 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.376763 [ 2902 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.377566 [ 2924 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.461535 [ 2939 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.638287 [ 2933 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.806815 [ 2937 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.851737 [ 2926 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:14.934653 [ 2912 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.006699 [ 2913 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.068472 [ 2938 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.175464 [ 2948 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.380648 [ 2941 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.381166 [ 2950 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.482517 [ 2954 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.641668 [ 2935 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.810513 [ 2959 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.855658 [ 2958 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:15.938608 [ 2960 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.010525 [ 2957 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.072051 [ 2952 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.254050 [ 2969 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.384528 [ 2973 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.385266 [ 2979 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.486476 [ 2968 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.645087 [ 2987 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.814128 [ 2982 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.859619 [ 2995 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:16.942257 [ 2984 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.013866 [ 2994 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.075534 [ 2976 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.257386 [ 3006 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.387880 [ 2910 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.388409 [ 3003 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.489489 [ 2996 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.621427 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.648080 [ 3001 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.818628 [ 3007 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.863887 [ 3004 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:17.946117 [ 3016 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.017602 [ 3022 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.079105 [ 3027 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.261084 [ 3019 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.392442 [ 3018 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.403905 [ 3009 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.492779 [ 3014 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.651494 [ 3024 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.822726 [ 3015 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.867328 [ 3039 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:18.949837 [ 3028 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.021508 [ 2894 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.103302 [ 3002 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.265166 [ 3030 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.414637 [ 3053 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.415541 [ 3046 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.496597 [ 3058 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.656015 [ 3056 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.827015 [ 3049 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.871418 [ 3062 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:19.954338 [ 3045 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.025788 [ 3011 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.190182 [ 3036 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.268457 [ 3067 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.418412 [ 3060 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.419072 [ 3059 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.501988 [ 3077 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.658796 [ 3052 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.830165 [ 3086 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.879367 [ 3085 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:20.957945 [ 3094 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.029684 [ 3090 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.192948 [ 3082 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.271618 [ 3089 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.421043 [ 3066 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.421783 [ 3096 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.504647 [ 3100 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.661544 [ 3093 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.832927 [ 3029 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.882100 [ 3098 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:21.961150 [ 3099 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.032638 [ 3109 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.195562 [ 3112 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.274563 [ 3114 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.429075 [ 3117 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.432434 [ 3044 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.507382 [ 3116 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.672377 [ 3088 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.836387 [ 3124 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.884915 [ 3127 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.899383 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:22.996315 [ 3132 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.035800 [ 3131 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.198336 [ 3144 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.277927 [ 3128 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.433038 [ 3135 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.436282 [ 3125 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.510339 [ 3140 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.676978 [ 3107 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.840185 [ 3150 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.887760 [ 3103 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:23.999184 [ 3170 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.038603 [ 3159 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.200668 [ 3171 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.366847 [ 3176 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.436342 [ 3178 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.439619 [ 3178 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.513568 [ 3185 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.680299 [ 3184 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.843471 [ 3168 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:24.890365 [ 3181 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.002326 [ 3192 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.041728 [ 3182 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.203315 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.379257 [ 3166 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.439635 [ 3197 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.442494 [ 3193 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.516781 [ 3172 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.683171 [ 3195 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.846667 [ 3209 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:25.894611 [ 3214 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.007826 [ 3204 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.044834 [ 3220 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.206106 [ 3203 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.382175 [ 3210 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.442456 [ 3217 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.445410 [ 3226 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.520319 [ 3201 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.686815 [ 3206 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.850014 [ 3223 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:26.898610 [ 3224 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.010608 [ 3230 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.047764 [ 3229 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.208980 [ 3239 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.385465 [ 3232 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.448765 [ 3242 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.557291 [ 3244 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.557436 [ 3241 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.708590 [ 3262 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.853801 [ 3236 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.902321 [ 3248 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:27.984398 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.014194 [ 3254 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.051728 [ 3252 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.280641 [ 3243 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.389391 [ 3266 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.452777 [ 3268 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.561413 [ 3277 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.561843 [ 3263 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.712576 [ 3267 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.857630 [ 2773 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:28.906387 [ 3250 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.018210 [ 3270 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.055775 [ 3279 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.284365 [ 3278 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.399252 [ 3276 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.456797 [ 3272 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.564904 [ 3273 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.565905 [ 2796 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.656009 [ 25324 ] {13a98639-0695-40c3-b790-9965cf1ec685} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58726) (comment: 02286_parallel_final.sh) (in query: DROP DATABASE IF EXISTS test_olhzuga2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:47:29.659579 [ 25324 ] {13a98639-0695-40c3-b790-9965cf1ec685} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.716728 [ 2803 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.772690 [ 25390 ] {863354b2-58cf-4aa6-811b-28740ea9ee3c} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58614) (comment: 02286_parallel_final.sh) (in query: DROP DATABASE IF EXISTS test_olhzuga2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:47:29.776793 [ 25390 ] {863354b2-58cf-4aa6-811b-28740ea9ee3c} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.861258 [ 3249 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.910333 [ 2798 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:29.966074 [ 18922 ] {38a3a6fc-1d90-43e2-b186-71ff49bf8d18} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58622) (comment: 02286_parallel_final.sh) (in query: DROP DATABASE IF EXISTS test_olhzuga2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:47:29.970631 [ 18922 ] {38a3a6fc-1d90-43e2-b186-71ff49bf8d18} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.022158 [ 2789 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.059255 [ 2777 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.257065 [ 25390 ] {1ab570f6-7d75-4460-8856-d1d166e79d1a} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58632) (comment: 02286_parallel_final.sh) (in query: DROP DATABASE IF EXISTS test_olhzuga2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:47:30.259326 [ 25390 ] {1ab570f6-7d75-4460-8856-d1d166e79d1a} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.287692 [ 2800 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.394432 [ 18922 ] {4d6bd91c-9326-4ade-83de-3ddfee529706} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58644) (comment: 02286_parallel_final.sh) (in query: DROP DATABASE IF EXISTS test_olhzuga2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:47:30.397682 [ 18922 ] {4d6bd91c-9326-4ade-83de-3ddfee529706} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.402089 [ 2799 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.460180 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.568359 [ 2780 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.569441 [ 2805 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.661099 [ 25390 ] {dfde25f6-e29e-4747-8bf5-4e89ed6dbc4b} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:58656) (comment: 02286_parallel_final.sh) (in query: DROP DATABASE IF EXISTS test_olhzuga2 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:47:30.720229 [ 2776 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.726907 [ 25390 ] {dfde25f6-e29e-4747-8bf5-4e89ed6dbc4b} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.864450 [ 2797 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:30.913568 [ 2813 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.024924 [ 2815 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.065971 [ 2814 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.290457 [ 2808 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.404917 [ 2826 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.463165 [ 2833 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.571807 [ 2829 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.572254 [ 2825 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.723048 [ 2822 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.867470 [ 2834 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.916745 [ 2824 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:31.936905 [ 18922 ] {d4daf871-c2ac-48d7-be78-d0134932dabb} executeQuery: Code: 36. DB::Exception: Unknown auxiliary ZooKeeper name 'zookeeper2'. If it's required it can be added to the section in config.xml. (BAD_ARGUMENTS) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:47964) (comment: 02735_system_zookeeper_connection.sql) (in query: CREATE TABLE test_zk_connection_table (`key` UInt64) ENGINE = ReplicatedMergeTree('zookeeper2:/clickhouse/{database}/02731_zk_connection/{shard}', '{replica}') ORDER BY tuple() SETTINGS index_granularity = 53354, 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 = 197100717, compact_parts_max_granules_to_buffer = 74, compact_parts_merge_max_bytes_to_prefetch_part = 26483708, merge_max_block_size = 1111, old_parts_lifetime = 41., 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 = 9949548827, index_granularity_bytes = 22116142, concurrent_part_removal_threshold = 0, allow_vertical_merges_from_compact_to_wide_parts = true, cache_populated_by_fetch = false, marks_compress_block_size = 33000, primary_key_compress_block_size = 18592), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/Context.cpp:3748: DB::Context::getAuxiliaryZooKeeper(String const&) const @ 0x000000002855e9ca 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:236: DB::StorageReplicatedMergeTree::setZooKeeper() @ 0x000000002ba21eaa 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000002ba25d9b 7. ./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&) @ 0x000000002cbc16db 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb809f 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:47:31.945825 [ 18922 ] {d4daf871-c2ac-48d7-be78-d0134932dabb} TCPHandler: Code: 36. DB::Exception: Unknown auxiliary ZooKeeper name 'zookeeper2'. If it's required it can be added to the section in config.xml. (BAD_ARGUMENTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Interpreters/Context.cpp:3748: DB::Context::getAuxiliaryZooKeeper(String const&) const @ 0x000000002855e9ca 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:236: DB::StorageReplicatedMergeTree::setZooKeeper() @ 0x000000002ba21eaa 6. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::StorageReplicatedMergeTree(String const&, String const&, DB::LoadingStrictnessLevel, DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>, DB::RenamingRestrictions, bool) @ 0x000000002ba25d9b 7. ./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&) @ 0x000000002cbc16db 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb809f 9. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 10. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 11. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 13. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 14. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 15. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 16. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 17. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 18. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 19. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 20. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 21. asan_thread_start(void*) @ 0x000000000aa47059 22. ? @ 0x00007f7519d19ac3 23. ? @ 0x00007f7519dab850 2025.10.23 23:47:32.028060 [ 2837 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.068759 [ 2840 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.292912 [ 2852 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.408047 [ 2857 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.494233 [ 2842 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.575184 [ 2830 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.576269 [ 2854 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.726691 [ 2866 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.870713 [ 2862 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:32.919889 [ 2844 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.031387 [ 2858 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.072095 [ 2871 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.096121 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.295327 [ 2876 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.411370 [ 2848 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.497782 [ 2861 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.578388 [ 2884 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.580981 [ 2887 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.732534 [ 2865 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.873308 [ 2888 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:33.922667 [ 2889 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.035238 [ 2890 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.074786 [ 2900 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.298208 [ 2903 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.401330 [ 18922 ] {61c3546c-9ba2-4a8a-97cc-28c39d896d2e} executeQuery: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:55752) (comment: 02952_conjunction_optimization.sql) (in query: DROP DATABASE IF EXISTS test_kwihx4ds ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 2025.10.23 23:47:34.404343 [ 18922 ] {61c3546c-9ba2-4a8a-97cc-28c39d896d2e} DynamicQueryHandler: Code: 219. DB::Exception: New table appeared in database being dropped or detached. Try again. (DATABASE_NOT_EMPTY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Interpreters/DatabaseCatalog.cpp:593: DB::DatabaseCatalog::detachDatabase(std::shared_ptr, String const&, bool, bool) @ 0x00000000286c0407 5. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203fb0 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 11. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 12. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 13. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 14. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 15. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 16. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 17. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 18. asan_thread_start(void*) @ 0x000000000aa47059 19. ? @ 0x00007f7519d19ac3 20. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.414532 [ 2892 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.500677 [ 2908 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.582147 [ 2880 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.604397 [ 2905 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.735491 [ 2878 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.876459 [ 2886 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:34.925810 [ 2845 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.038609 [ 2914 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.078191 [ 2917 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.302026 [ 2907 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.422715 [ 2918 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.504076 [ 2925 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.586396 [ 2911 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.607832 [ 2916 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.739641 [ 2924 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.880007 [ 2921 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:35.931149 [ 2909 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.042242 [ 2933 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.082822 [ 2802 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.304995 [ 2929 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.425054 [ 2913 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.506540 [ 2942 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.569278 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.589222 [ 2948 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.610507 [ 2934 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.744657 [ 2955 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.883233 [ 2958 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:36.934735 [ 2943 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.045524 [ 2964 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.086318 [ 2947 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.308182 [ 2963 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.428790 [ 2952 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.509388 [ 2962 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.592419 [ 2965 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.613599 [ 2978 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.747899 [ 2979 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.886610 [ 2968 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:37.939329 [ 2956 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.048580 [ 2983 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.089431 [ 2986 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.191663 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.312145 [ 2988 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.432505 [ 2982 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.512625 [ 2990 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.595626 [ 2994 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.616471 [ 2977 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.750859 [ 3006 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.889942 [ 2991 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:38.942661 [ 2951 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.051369 [ 3007 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.092123 [ 3008 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.315516 [ 3016 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.438729 [ 3017 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.520100 [ 2981 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.598844 [ 3013 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.620040 [ 2989 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.753649 [ 3035 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.893353 [ 3024 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:39.946024 [ 3031 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.054238 [ 3041 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.095074 [ 3020 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.318598 [ 3034 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.442172 [ 3038 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.524122 [ 3043 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.602811 [ 3053 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.623908 [ 3046 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.757385 [ 3042 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.897332 [ 3058 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:40.950477 [ 3023 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.060790 [ 3057 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.099167 [ 3055 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.322496 [ 3011 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.446698 [ 3063 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.528019 [ 3060 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.606800 [ 3059 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.627677 [ 3068 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.761219 [ 3048 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.901133 [ 3052 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:41.954346 [ 3084 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.065011 [ 3094 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.103102 [ 3091 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.326051 [ 3078 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.450467 [ 3089 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.532283 [ 3026 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.610387 [ 3097 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.631359 [ 3066 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.764112 [ 3079 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.905182 [ 3093 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:42.958435 [ 3087 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.068606 [ 3029 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.106554 [ 3098 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.301114 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.330348 [ 3101 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.453861 [ 3073 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.535791 [ 3120 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.614042 [ 3110 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.634916 [ 3117 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.767700 [ 3116 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:43.961549 [ 3124 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.006143 [ 3105 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.071531 [ 3122 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.109374 [ 3132 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.334822 [ 3128 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.457457 [ 3135 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.539292 [ 3125 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.617581 [ 3142 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.638318 [ 3140 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.771257 [ 3146 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:44.965573 [ 3154 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.009176 [ 3150 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.074030 [ 3103 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.112555 [ 3145 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.338303 [ 3161 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.460893 [ 3171 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.543135 [ 3164 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.621316 [ 3136 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.641812 [ 3176 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.775465 [ 3179 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:45.970224 [ 3162 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.012685 [ 3185 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.076958 [ 3153 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.115445 [ 3174 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.341588 [ 3181 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.464814 [ 3187 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.546869 [ 3175 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.625135 [ 3186 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.645861 [ 3194 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.779364 [ 3191 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:46.974512 [ 3200 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.016290 [ 3189 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.080100 [ 3196 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.118708 [ 3202 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.434963 [ 3207 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.467566 [ 3211 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.553467 [ 3220 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.628675 [ 3177 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.649748 [ 3222 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.782807 [ 3149 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:47.986250 [ 3151 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.019509 [ 3217 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.084133 [ 3206 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.122381 [ 3234 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.438386 [ 3224 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.478107 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.481083 [ 3230 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.557205 [ 3229 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.636376 [ 3235 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.654718 [ 3213 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.787008 [ 3239 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:48.989729 [ 3237 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.026442 [ 3238 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.088497 [ 3246 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.126458 [ 3221 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.441986 [ 3248 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.484792 [ 3227 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.566072 [ 3254 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.640577 [ 3265 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.658796 [ 3251 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.791374 [ 3245 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:49.993851 [ 3258 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.030856 [ 3264 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.091479 [ 3255 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.166463 [ 3282 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.446195 [ 2775 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.488983 [ 3253 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.569719 [ 3270 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.644481 [ 3261 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.662189 [ 3260 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.795152 [ 3276 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:50.997103 [ 3228 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.035520 [ 2796 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.094311 [ 2785 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.169091 [ 3256 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.450160 [ 2806 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.492296 [ 2798 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.573660 [ 3183 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.647272 [ 2778 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.664993 [ 2788 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:51.797686 [ 2782 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.001133 [ 2799 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.038363 [ 2780 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.097070 [ 2805 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.171995 [ 2776 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.453467 [ 2813 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.495926 [ 2811 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.584711 [ 2817 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.650599 [ 2815 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.668111 [ 2784 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:52.801356 [ 2808 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.036548 [ 2826 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.041944 [ 2787 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.100819 [ 2829 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.175546 [ 2825 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.461221 [ 2820 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.499220 [ 2836 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.587981 [ 2819 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.593024 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.654729 [ 2834 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.672702 [ 2824 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:53.804787 [ 2840 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.040069 [ 2847 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.044470 [ 2852 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.104641 [ 2855 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.178878 [ 2856 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.464692 [ 2841 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.502222 [ 2862 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.591254 [ 2870 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.658961 [ 2868 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.676450 [ 2872 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:54.808443 [ 2871 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.043090 [ 2848 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.047369 [ 2875 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.107314 [ 2864 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.181390 [ 2861 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.539659 [ 2896 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.540194 [ 2873 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.594154 [ 2893 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.661828 [ 2890 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.679989 [ 2900 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:55.818549 [ 2897 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.046638 [ 2908 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.056522 [ 2883 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.110270 [ 2880 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.184676 [ 2794 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.543763 [ 2917 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.543948 [ 2901 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.597464 [ 2918 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.665104 [ 2923 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.683142 [ 2922 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:56.821947 [ 2931 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.050164 [ 2919 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.059423 [ 2924 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.113046 [ 2927 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.187978 [ 2921 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.546700 [ 2930 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.547135 [ 2936 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.600349 [ 2928 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.668401 [ 2929 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.686408 [ 2912 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:57.825119 [ 2885 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.052850 [ 2934 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.062150 [ 2944 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.115856 [ 2954 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.190611 [ 2935 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.549895 [ 2945 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.550707 [ 2972 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.603233 [ 2958 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.680510 [ 2943 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.689547 [ 2966 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.762939 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:58.832027 [ 2947 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.056706 [ 2967 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.065011 [ 2969 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.119251 [ 2965 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.193361 [ 2953 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.561321 [ 2987 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.562133 [ 2986 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.606239 [ 2783 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.683870 [ 2980 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.692755 [ 2999 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:47:59.835577 [ 2995 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.059911 [ 2985 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.067976 [ 2977 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.122575 [ 3010 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.196572 [ 3003 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.564376 [ 3001 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.565647 [ 3000 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.609639 [ 3004 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.695162 [ 3016 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.696905 [ 2993 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:00.839274 [ 2981 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.063827 [ 3019 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.071824 [ 3013 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.126312 [ 2989 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.200064 [ 3009 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.575106 [ 3021 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.575210 [ 3015 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.612532 [ 3020 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.699458 [ 2894 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.700815 [ 3034 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:01.842834 [ 3032 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.067269 [ 3047 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.075284 [ 3053 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.129600 [ 3046 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.203479 [ 3030 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.579554 [ 3023 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.609318 [ 3050 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.616141 [ 3057 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.702502 [ 3049 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.770648 [ 3070 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:02.846512 [ 3045 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.070053 [ 3060 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.077793 [ 3059 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.132574 [ 3077 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.209432 [ 3065 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.582882 [ 3086 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.612619 [ 3090 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.619322 [ 3091 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.705136 [ 3082 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.773895 [ 3064 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.849591 [ 3078 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:03.947308 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.072761 [ 3089 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.080215 [ 3026 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.135735 [ 3081 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.212033 [ 3096 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.585806 [ 3029 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.615409 [ 3098 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.621671 [ 3076 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.708176 [ 3101 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.829809 [ 3102 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:04.852366 [ 3112 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.082283 [ 3110 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.130833 [ 3117 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.138373 [ 3044 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.214873 [ 3111 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.589116 [ 3105 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.618232 [ 3122 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.624500 [ 3132 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.711317 [ 3123 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.833179 [ 3129 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:05.855985 [ 3130 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.085507 [ 3131 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.140118 [ 3126 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.141639 [ 3133 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.218837 [ 3135 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.592478 [ 3107 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.621634 [ 3148 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.665353 [ 3103 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.715152 [ 3145 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.836890 [ 3159 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:06.860203 [ 3161 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.088747 [ 3171 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.143255 [ 3167 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.144249 [ 3164 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.222536 [ 3179 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.595444 [ 3174 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.624759 [ 3180 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.669435 [ 3173 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.718559 [ 3184 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.840261 [ 3168 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:07.863282 [ 3192 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.092221 [ 3175 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.146529 [ 3194 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.147240 [ 3139 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.226092 [ 3197 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.605410 [ 3199 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.618538 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.628600 [ 3189 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.673373 [ 3172 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.722411 [ 3195 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.867131 [ 3198 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:08.936540 [ 3202 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.037428 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.095550 [ 3208 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.150006 [ 3220 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.150630 [ 3177 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.229338 [ 3216 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.609388 [ 3152 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.632042 [ 3151 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.677436 [ 3217 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.726316 [ 3201 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.871032 [ 3234 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:09.940285 [ 3157 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.099070 [ 3223 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.153825 [ 3224 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.154482 [ 3230 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.241337 [ 3235 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.617461 [ 3237 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.635466 [ 3242 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.681009 [ 3238 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.730105 [ 3246 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.874048 [ 3247 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:10.943159 [ 3236 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.157025 [ 3251 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.157562 [ 3243 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.197618 [ 3254 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.245344 [ 3245 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.621060 [ 3268 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.639128 [ 3277 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.643700 [ 3386 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6d7bfeba-2878-4bef-86bb-b5da6ac05b55::202510_1_182_57}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.684627 [ 3269 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.733468 [ 3255 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.925210 [ 3250 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:11.946023 [ 2775 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.159861 [ 3253 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.160716 [ 3270 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.200240 [ 3261 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.299689 [ 3260 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.624111 [ 3273 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.642308 [ 2796 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.692065 [ 2785 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.736742 [ 2790 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.928285 [ 2772 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:12.983984 [ 3249 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.163472 [ 2778 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.164701 [ 2788 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.203988 [ 2777 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.304108 [ 2795 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.627335 [ 2781 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.645463 [ 2780 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.695763 [ 2805 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.740660 [ 2776 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.931653 [ 2809 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:13.987341 [ 2813 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.122858 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.168366 [ 2811 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.172095 [ 2807 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.208512 [ 2812 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.308374 [ 2815 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.631203 [ 2821 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.649293 [ 2823 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.673859 [ 3388 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {855a1c57-459a-4184-97ab-17bc8cfce245::202510_1_191_38}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.699479 [ 2829 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.744516 [ 2832 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.935385 [ 2820 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:14.991166 [ 2836 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.171589 [ 2834 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.175441 [ 2824 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.212204 [ 2818 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.312181 [ 2837 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.653124 [ 2847 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.703775 [ 2850 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.730178 [ 2843 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.748532 [ 2857 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.938611 [ 2830 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:15.995161 [ 2854 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.174724 [ 2846 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.178736 [ 2862 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.215474 [ 2868 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.315956 [ 2872 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.613329 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.657272 [ 2848 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.707897 [ 2875 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.735647 [ 2864 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.752409 [ 2859 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.941830 [ 2896 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:16.997804 [ 2888 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.177381 [ 2889 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.181027 [ 2893 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.218568 [ 2853 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.330786 [ 2890 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.660522 [ 2908 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.711105 [ 2880 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.738734 [ 2794 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.755951 [ 2905 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:17.945113 [ 2914 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.000937 [ 2917 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.179777 [ 2907 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.183424 [ 2918 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.221196 [ 2923 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.333877 [ 2931 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.664083 [ 2919 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.714682 [ 2902 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.742221 [ 2906 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.759288 [ 2927 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:18.948696 [ 2909 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.005449 [ 2802 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.182640 [ 2936 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.186360 [ 2928 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.208893 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.223856 [ 2929 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.412888 [ 2937 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.667442 [ 2946 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.725556 [ 2942 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.745687 [ 2940 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.762895 [ 2948 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:19.968084 [ 2950 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.008823 [ 2954 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.185370 [ 2935 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.189381 [ 2955 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.226613 [ 2945 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.415745 [ 2943 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.670772 [ 2961 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.729230 [ 2952 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.766102 [ 2962 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.802463 [ 2960 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:20.971620 [ 2978 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.012051 [ 2979 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.191192 [ 2974 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.192736 [ 2968 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.229525 [ 2920 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.418876 [ 2980 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.674108 [ 2995 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.732441 [ 2984 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.769471 [ 2994 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.805959 [ 2977 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:21.975246 [ 3010 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.014848 [ 2971 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.194706 [ 2991 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.195349 [ 2910 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.232309 [ 2996 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.422698 [ 3000 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.677616 [ 3004 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.735838 [ 2993 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.870662 [ 3017 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.871107 [ 3025 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:22.978321 [ 3019 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.017927 [ 3013 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.198837 [ 3018 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.205754 [ 3033 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.234864 [ 3005 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.426498 [ 3035 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.681319 [ 3015 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.740142 [ 3041 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.874668 [ 2894 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.875244 [ 3034 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:23.981813 [ 3002 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.021289 [ 3038 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.201655 [ 3047 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.237647 [ 3046 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.251511 [ 3030 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.364673 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.429802 [ 3056 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.684633 [ 3057 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.764549 [ 3049 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.878196 [ 3070 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.878766 [ 3062 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:24.989667 [ 3051 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.024460 [ 3071 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.207995 [ 3061 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.240976 [ 3067 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.254355 [ 3060 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.433008 [ 3077 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.687887 [ 3084 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.769763 [ 3086 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.890794 [ 3085 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:25.891559 [ 3090 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.007641 [ 3091 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.027794 [ 3082 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.211273 [ 3064 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.244231 [ 3094 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.257645 [ 3089 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.439421 [ 3097 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.691413 [ 3095 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.773476 [ 3072 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.894555 [ 3093 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:26.895461 [ 3029 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.011150 [ 3099 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.031552 [ 3104 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.222309 [ 3112 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.247747 [ 3073 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.261010 [ 3115 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.443492 [ 3111 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.695446 [ 3113 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.777887 [ 3116 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.898337 [ 3124 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:27.898982 [ 3105 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.035094 [ 3122 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.100566 [ 3127 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.226048 [ 3144 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.251672 [ 3128 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.264860 [ 3108 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.447792 [ 3135 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.699590 [ 3142 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.785418 [ 3140 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.902878 [ 3137 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:28.903702 [ 3143 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.039455 [ 3107 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.103952 [ 3150 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.229750 [ 3145 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.255571 [ 3160 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.269088 [ 3170 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.451747 [ 3159 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.549825 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.705819 [ 3167 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.789346 [ 3176 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.907175 [ 3179 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:29.908059 [ 3178 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.043395 [ 3185 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.107543 [ 3153 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.234518 [ 3184 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.259397 [ 3118 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.272681 [ 3138 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.469317 [ 3192 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.709757 [ 3181 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.793575 [ 3175 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.910991 [ 3194 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:30.911551 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.046906 [ 3191 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.111140 [ 3193 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.238144 [ 3189 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.263326 [ 3200 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.281026 [ 3172 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.473301 [ 3202 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.713497 [ 3214 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.797334 [ 3211 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.915035 [ 3204 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:31.915966 [ 3220 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.050037 [ 3216 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.114230 [ 3149 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.241143 [ 3210 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.266302 [ 3151 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.291325 [ 3218 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.476950 [ 3226 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.720626 [ 3234 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.800974 [ 3157 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.918599 [ 3225 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:32.919267 [ 3224 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.053202 [ 3235 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.117091 [ 3213 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.244236 [ 3232 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.269481 [ 3233 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.294741 [ 3215 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.480237 [ 3246 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.725048 [ 3247 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.804425 [ 3236 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.923532 [ 3259 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:33.924134 [ 3227 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.057059 [ 3252 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.120237 [ 3251 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.247482 [ 3243 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.273086 [ 3254 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.306399 [ 3258 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.484407 [ 3277 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.728708 [ 3282 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.807443 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.808042 [ 2775 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.927730 [ 3253 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:34.928486 [ 3270 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.068435 [ 3261 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.123702 [ 3260 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.252470 [ 3278 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.276916 [ 3147 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.310116 [ 3272 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.489052 [ 3228 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.732788 [ 2790 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.812743 [ 3256 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.932168 [ 2803 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:35.933096 [ 2772 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.072380 [ 3283 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.127935 [ 2798 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.255775 [ 2789 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.280567 [ 2778 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.313958 [ 2788 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.493057 [ 2800 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.762745 [ 3212 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.817366 [ 2786 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.936657 [ 2801 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:36.937544 [ 2809 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.076100 [ 2811 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.131494 [ 2807 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.259338 [ 2812 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.283928 [ 2817 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.317301 [ 3271 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.497201 [ 2816 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.772489 [ 2810 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.821267 [ 2829 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.940762 [ 2825 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:37.941784 [ 2835 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.079580 [ 2820 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.134064 [ 2819 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.262192 [ 2834 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.287102 [ 2818 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.320221 [ 2837 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.500933 [ 2828 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.775573 [ 2850 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.824308 [ 2843 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.947353 [ 2863 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:38.948024 [ 2869 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.082484 [ 2842 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.137476 [ 2867 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.265709 [ 2846 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.290202 [ 2862 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.323766 [ 2868 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.550990 [ 2871 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.779181 [ 2859 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.827532 [ 2861 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.952921 [ 2887 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.953786 [ 2896 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:39.970542 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.086104 [ 2865 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.141609 [ 2873 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.269299 [ 2888 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.293705 [ 2882 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.327448 [ 2898 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.554648 [ 2853 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.783010 [ 2892 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.831114 [ 2877 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.956308 [ 2880 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:40.957079 [ 2794 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.090049 [ 2886 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.145556 [ 2915 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.272092 [ 2901 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.297203 [ 2907 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.330610 [ 2923 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.558984 [ 2919 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.786509 [ 2939 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.834990 [ 2895 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.960198 [ 2909 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:41.960531 [ 2933 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.095332 [ 2936 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.148411 [ 2928 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.274832 [ 2937 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.300318 [ 2912 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.333419 [ 2932 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.562283 [ 2938 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.790115 [ 2934 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.838451 [ 2950 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.964053 [ 2941 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:42.964594 [ 2945 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.099741 [ 2972 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.151621 [ 2959 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.277846 [ 2943 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.303488 [ 2966 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.336634 [ 2947 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.565414 [ 2963 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.794154 [ 2962 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.841802 [ 2960 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.968402 [ 2969 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:43.968551 [ 2965 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.155354 [ 2953 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.168164 [ 2979 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.281559 [ 2956 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.317303 [ 2920 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.346668 [ 2987 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.570182 [ 2980 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.798202 [ 2982 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.881552 [ 2977 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.972777 [ 2992 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:44.973401 [ 3010 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.102802 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.158549 [ 2971 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.209459 [ 3006 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.284113 [ 2951 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.320226 [ 2970 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.349933 [ 3001 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.574509 [ 3004 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.804495 [ 2993 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.885162 [ 3022 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.976910 [ 3017 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:45.978019 [ 3025 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.162334 [ 3009 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.213734 [ 3018 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.286973 [ 3033 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.323970 [ 3014 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.353432 [ 3035 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.578426 [ 3041 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.808092 [ 3020 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.889031 [ 3028 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.981243 [ 3034 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:46.982219 [ 3002 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.165876 [ 3047 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.217970 [ 3046 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.291453 [ 3030 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.327793 [ 3042 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.356839 [ 3058 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.581753 [ 3054 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.815905 [ 3057 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.892579 [ 3049 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.985414 [ 3045 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:47.986070 [ 3051 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.169162 [ 3036 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.221431 [ 3061 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.295067 [ 3080 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.331550 [ 3067 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.360678 [ 3060 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.585017 [ 3052 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.819656 [ 3083 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.896740 [ 3085 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.989385 [ 3091 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:48.995144 [ 3082 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.172677 [ 3094 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.224363 [ 3089 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.298512 [ 3074 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.335145 [ 3096 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.365159 [ 3097 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.589393 [ 3079 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.823330 [ 3076 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.900415 [ 3104 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.992886 [ 3101 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:49.998698 [ 2975 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.176000 [ 3102 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.227747 [ 3112 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.302239 [ 3120 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.338679 [ 3110 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.354936 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.368493 [ 3044 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.593345 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.827223 [ 3124 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.904322 [ 3105 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:50.996525 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.001927 [ 3123 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.179248 [ 3130 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.231778 [ 3133 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.306567 [ 3108 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.342189 [ 3135 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.372072 [ 3125 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.597064 [ 3137 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.830380 [ 3141 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:51.908027 [ 3119 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.000320 [ 3107 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.005833 [ 3150 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.182398 [ 3163 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.235164 [ 3170 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.310199 [ 3159 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.345771 [ 3158 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.375145 [ 3167 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.601022 [ 3176 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.832923 [ 3162 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:52.911334 [ 3188 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.007761 [ 3174 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.010030 [ 3173 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.185901 [ 3168 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.238568 [ 3192 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.314098 [ 3181 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.349512 [ 3175 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.378452 [ 3194 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.604872 [ 3199 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.835822 [ 3172 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:53.915681 [ 3209 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.011601 [ 3214 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.013372 [ 3208 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.189626 [ 3177 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.242425 [ 3190 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.317612 [ 3216 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.421819 [ 3219 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.422969 [ 3152 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.609300 [ 3218 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.845938 [ 3234 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:54.919289 [ 3231 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.014793 [ 3225 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.016256 [ 3224 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.283651 [ 3155 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.284333 [ 3213 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.321008 [ 3239 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.425295 [ 3233 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.426064 [ 3215 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.436867 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.612564 [ 3246 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.853061 [ 3240 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:55.922558 [ 3259 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.018457 [ 3248 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.019539 [ 3252 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.286409 [ 3266 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.287449 [ 3258 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.324145 [ 3268 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.428610 [ 3267 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.428851 [ 3282 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.619745 [ 3250 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.856845 [ 2775 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:56.926206 [ 3257 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.022121 [ 3253 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.023030 [ 3270 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.289659 [ 3273 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.290761 [ 2796 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.332741 [ 2785 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.432702 [ 3256 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.433367 [ 2804 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.624030 [ 2803 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.860871 [ 2806 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:57.929313 [ 2798 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.025418 [ 3280 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.026124 [ 2789 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.293243 [ 2795 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.294393 [ 2782 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.336299 [ 2800 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.482642 [ 2781 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.483283 [ 2780 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.627490 [ 2801 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.864221 [ 2797 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:58.933262 [ 2811 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.028837 [ 2812 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.032758 [ 2817 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.300886 [ 2784 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.301550 [ 2816 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.339820 [ 2831 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.487166 [ 2827 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.487638 [ 2808 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.631435 [ 2823 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.868737 [ 2832 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:48:59.936514 [ 2820 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.032573 [ 2822 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.036323 [ 2819 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.304400 [ 2824 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.305219 [ 2818 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.346057 [ 2837 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.490510 [ 2849 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.490980 [ 2847 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.627962 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.636525 [ 2850 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:00.873878 [ 2857 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.019713 [ 2869 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.035363 [ 2854 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.038734 [ 2842 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.307481 [ 2866 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.307914 [ 2867 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.349157 [ 2862 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.493513 [ 2858 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.494170 [ 2851 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.640397 [ 2848 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:01.946808 [ 2881 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.022240 [ 2859 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.037530 [ 2884 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.041122 [ 2887 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.310072 [ 2882 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.311117 [ 2898 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.356553 [ 2891 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.497174 [ 2791 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.497708 [ 2897 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.644002 [ 2903 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:02.949919 [ 2905 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.032285 [ 2878 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.040629 [ 2845 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.044122 [ 2845 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.313678 [ 2917 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.314153 [ 2901 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.426923 [ 2918 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.506126 [ 2925 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.506223 [ 2911 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.648003 [ 2916 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:03.952878 [ 2895 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.036472 [ 2933 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.043868 [ 2909 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.047429 [ 2909 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.316773 [ 2928 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.317417 [ 2929 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.447663 [ 2912 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.509105 [ 2913 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.509596 [ 2926 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.651408 [ 2942 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:04.956440 [ 2940 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.039965 [ 2944 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.046869 [ 2935 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.055096 [ 2955 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.319940 [ 2949 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.320486 [ 2943 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.450850 [ 2947 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.512576 [ 2961 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.512940 [ 2963 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.656426 [ 2952 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.846670 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:05.959957 [ 2969 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.043200 [ 2973 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.049992 [ 2953 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.060174 [ 2979 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.323496 [ 2920 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.323794 [ 2987 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.463938 [ 2783 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.516401 [ 2999 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.516927 [ 2988 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.660287 [ 2982 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.709954 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:06.963450 [ 2985 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.047019 [ 2992 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.053684 [ 3010 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.063482 [ 2971 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.326427 [ 2991 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.327094 [ 2910 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.467499 [ 3000 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.520153 [ 3008 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.526439 [ 3004 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.664069 [ 3017 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:07.966838 [ 2981 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.050738 [ 3013 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.057104 [ 2989 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.066861 [ 3012 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.330224 [ 3033 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.330422 [ 3005 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.471595 [ 3014 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.529457 [ 2998 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.530630 [ 3024 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.667815 [ 3021 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:08.970316 [ 3020 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.054022 [ 2894 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.060668 [ 3034 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.070090 [ 3038 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.333935 [ 3046 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.334832 [ 3030 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.474990 [ 3056 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.533236 [ 3054 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.533905 [ 3050 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.670820 [ 3055 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:09.973272 [ 3062 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.056726 [ 3071 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.063358 [ 3063 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.072453 [ 3036 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.337597 [ 3059 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.344006 [ 3077 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.478232 [ 3052 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.536889 [ 3075 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.537594 [ 3069 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.674487 [ 3084 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.960986 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:10.979644 [ 3082 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.060601 [ 3078 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.067303 [ 3094 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.076598 [ 3089 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.341209 [ 3074 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.348173 [ 3096 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.481436 [ 3072 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.540484 [ 3087 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.541028 [ 3093 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.678096 [ 3104 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:11.983737 [ 3112 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.064726 [ 3073 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.080569 [ 3115 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.129067 [ 3120 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.344770 [ 3044 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.351828 [ 3111 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.485350 [ 3113 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.544543 [ 3116 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.544981 [ 3106 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.682048 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:12.987292 [ 3123 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.068431 [ 3126 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.084065 [ 3130 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.132180 [ 3133 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.348251 [ 3125 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.354840 [ 3134 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.488852 [ 3140 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.548349 [ 3143 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.548937 [ 3146 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.685876 [ 3119 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:13.990557 [ 3150 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.071903 [ 3103 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.087739 [ 3145 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.135457 [ 3160 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.352074 [ 3156 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.358192 [ 3171 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.500782 [ 3164 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.552601 [ 3136 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.553781 [ 3176 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.689766 [ 3178 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:14.994699 [ 3174 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.077441 [ 3118 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.091062 [ 3138 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.138918 [ 3192 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.355962 [ 3175 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.361952 [ 3194 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.504727 [ 3191 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.556048 [ 3193 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.557471 [ 3199 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.693674 [ 3172 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:15.999286 [ 3209 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.062663 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.081000 [ 3208 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.094687 [ 3211 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.149160 [ 3220 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.359726 [ 3149 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.365490 [ 3222 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.508342 [ 3218 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.558931 [ 3226 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.560121 [ 3201 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:16.697382 [ 3206 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.003259 [ 3223 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.085073 [ 3225 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.162855 [ 3230 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.170108 [ 3229 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.363954 [ 3155 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.369355 [ 3213 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.512968 [ 3233 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.562720 [ 3237 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.563512 [ 3242 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:17.701115 [ 3244 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.007618 [ 3259 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.093755 [ 3227 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.166755 [ 3248 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.174445 [ 3252 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.368720 [ 3251 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.378544 [ 3243 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.516795 [ 3258 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.566702 [ 3277 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.567106 [ 3263 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:18.705331 [ 3264 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.011311 [ 3269 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.097541 [ 3250 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.171139 [ 3275 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.191098 [ 3253 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.373111 [ 3261 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.382659 [ 3260 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.520647 [ 3272 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.570167 [ 3228 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.571035 [ 2779 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:19.708069 [ 2796 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.014323 [ 3256 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.100603 [ 2772 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.174609 [ 2792 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.194093 [ 2806 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.376493 [ 3249 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.386025 [ 3280 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.524003 [ 2777 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.573709 [ 2782 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.574316 [ 2800 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:20.711050 [ 2780 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.017686 [ 2776 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.103679 [ 2801 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.177617 [ 2809 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.196903 [ 2797 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.315031 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.379494 [ 2813 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.388751 [ 2793 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.527029 [ 3271 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.576878 [ 2815 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.577389 [ 2784 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:21.722292 [ 2827 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.020958 [ 2826 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.107125 [ 2787 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.180964 [ 2835 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.200251 [ 2825 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.382730 [ 2820 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.392249 [ 2836 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.531061 [ 2819 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.580832 [ 2824 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.581777 [ 2818 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:22.726140 [ 2840 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.025578 [ 2850 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.111038 [ 2852 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.184587 [ 2843 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.210615 [ 2863 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.386343 [ 2830 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.395782 [ 2869 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.534461 [ 2866 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.584571 [ 2867 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.585175 [ 2846 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:23.730462 [ 2841 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.030183 [ 2851 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.172008 [ 2876 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.188306 [ 2848 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.214461 [ 2875 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.392882 [ 2861 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.399472 [ 2884 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.543868 [ 2887 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.588831 [ 2865 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.589894 [ 2873 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:24.733961 [ 2891 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.034037 [ 2900 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.175820 [ 2791 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.191262 [ 2903 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.217984 [ 2892 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.396178 [ 2899 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.402717 [ 2883 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.547310 [ 2878 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.591974 [ 2886 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.593263 [ 2845 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:25.737601 [ 2907 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.037696 [ 2922 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.183417 [ 2911 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.194361 [ 2931 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.220853 [ 2916 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.398873 [ 2927 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.405674 [ 2921 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.425461 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.550534 [ 2930 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.595143 [ 2936 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.596413 [ 2928 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:26.741273 [ 2937 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.040657 [ 2912 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.187069 [ 2913 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.207275 [ 2926 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.223640 [ 2942 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.401660 [ 2940 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.408626 [ 2944 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.558745 [ 2941 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.598714 [ 2959 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.600312 [ 2972 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:27.745146 [ 2958 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.043419 [ 2961 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.189940 [ 2964 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.210008 [ 2957 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.227049 [ 2952 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.404648 [ 2960 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.411579 [ 2969 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.562643 [ 2978 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.601755 [ 2973 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.609266 [ 2953 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.728492 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:28.748011 [ 2968 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.046214 [ 2986 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.193039 [ 2980 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.213033 [ 2783 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.230045 [ 2999 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.407877 [ 2995 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.419023 [ 2984 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.566074 [ 2985 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.604801 [ 2976 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.612729 [ 2992 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:29.751621 [ 3006 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.049487 [ 2996 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.196839 [ 2970 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.216354 [ 3001 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.233927 [ 3007 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.411424 [ 3017 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.422842 [ 3025 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.570059 [ 2981 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.608812 [ 2989 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.623622 [ 3012 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:30.755045 [ 3033 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.052546 [ 3014 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.199926 [ 2998 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.220116 [ 3031 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.237346 [ 3021 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.426399 [ 3041 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.493507 [ 3015 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.573991 [ 3002 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.582104 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.612519 [ 3038 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.626837 [ 3040 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:31.771757 [ 3053 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.055270 [ 3042 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.202493 [ 3055 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.227362 [ 3049 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.241198 [ 3023 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.429712 [ 3070 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.496815 [ 3062 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.620320 [ 3011 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.620593 [ 3071 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.631141 [ 3063 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:32.776035 [ 3061 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.058035 [ 3077 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.205752 [ 3052 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.231605 [ 3075 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.244461 [ 3069 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.441867 [ 3083 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.499933 [ 3090 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.624075 [ 3091 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.624811 [ 3082 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.634595 [ 3064 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:33.779803 [ 3094 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.060796 [ 3100 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.208801 [ 3095 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.234804 [ 3092 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.253582 [ 3072 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.444890 [ 3098 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.512727 [ 3076 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.627951 [ 3109 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.632467 [ 2975 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.646217 [ 3102 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:34.786242 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.063190 [ 3111 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.211589 [ 3113 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.237318 [ 3116 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.260393 [ 3106 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.448020 [ 3105 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.515439 [ 3127 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.631835 [ 3131 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.635344 [ 3126 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.649146 [ 3133 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:35.788903 [ 3108 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.065768 [ 3137 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.215439 [ 3146 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.240986 [ 3141 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.263573 [ 3119 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.457003 [ 3163 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.520897 [ 3103 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.635292 [ 3160 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.638629 [ 3170 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.658927 [ 3159 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.742115 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:36.792711 [ 3158 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.068622 [ 3136 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.218218 [ 3179 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.243730 [ 3162 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.266561 [ 3169 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.460548 [ 3118 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.527483 [ 3138 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.638344 [ 3192 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.641709 [ 3192 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.662008 [ 3165 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:37.796048 [ 3186 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.072244 [ 3166 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.221351 [ 3182 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.246149 [ 3191 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.268938 [ 3193 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.463811 [ 3189 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.530557 [ 3196 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.641168 [ 3214 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.644291 [ 3208 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.664443 [ 3202 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:38.798914 [ 3211 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.075759 [ 3190 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.224705 [ 3222 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.248600 [ 3219 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.272276 [ 3210 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.467266 [ 3217 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.535820 [ 3205 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.647447 [ 3234 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.662531 [ 3157 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.667297 [ 3231 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:39.802093 [ 3225 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.078657 [ 3155 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.227890 [ 3213 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.251345 [ 3239 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.275403 [ 3232 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.470891 [ 3242 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.539101 [ 3246 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.650639 [ 3241 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.665415 [ 3244 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.670297 [ 3240 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:40.805021 [ 3259 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.082087 [ 3252 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.256437 [ 3265 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.258936 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.278489 [ 3254 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.474767 [ 3268 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.542476 [ 3263 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.669245 [ 3255 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.674375 [ 3269 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.654245 [ 2774 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:41.809185 [ 3250 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.089345 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.095342 [ 3275 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.260163 [ 3279 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.262290 [ 3261 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.281628 [ 3278 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.479482 [ 3272 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.591587 [ 2779 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.720445 [ 2796 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.721100 [ 2785 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.804219 [ 3147 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:42.813573 [ 2790 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.099342 [ 2806 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.263903 [ 3249 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.266401 [ 3280 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.286403 [ 2789 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.486040 [ 2777 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.655177 [ 2799 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.724555 [ 2781 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.725341 [ 2780 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.808141 [ 3212 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:43.817239 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.102605 [ 2797 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.267822 [ 2793 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.269747 [ 2811 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.289598 [ 2807 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.489160 [ 3271 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.658352 [ 2816 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.727552 [ 2831 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.728252 [ 2827 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.811398 [ 2808 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:44.820247 [ 3281 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.105932 [ 2787 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.270640 [ 2832 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.272921 [ 2820 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.292596 [ 2836 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.500308 [ 2819 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.666426 [ 2818 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.730621 [ 2837 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.731225 [ 2840 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.814574 [ 2828 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:45.822927 [ 2849 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.109268 [ 2843 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.274434 [ 2857 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.276217 [ 2830 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.295961 [ 2869 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.503421 [ 2846 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.670074 [ 2868 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.733878 [ 2844 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.734850 [ 2872 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.818526 [ 2858 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:46.827723 [ 2851 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.112398 [ 2875 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.169022 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.277485 [ 2861 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.367671 [ 2859 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.368183 [ 2884 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.506832 [ 2865 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.674042 [ 2896 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.743508 [ 2882 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.746006 [ 2898 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.822701 [ 2893 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:47.831710 [ 2853 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.115971 [ 2903 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.284294 [ 2877 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.371244 [ 2794 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.371941 [ 2905 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.510777 [ 2904 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.678021 [ 2845 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.747187 [ 2915 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.749443 [ 2914 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.826797 [ 2907 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:48.835774 [ 2901 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.120223 [ 2925 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.361833 [ 2902 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.441898 [ 2927 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.465525 [ 2906 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.514896 [ 2939 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.717613 [ 2921 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.751095 [ 2933 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.752838 [ 2802 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.830641 [ 2930 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:49.839525 [ 2928 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.129295 [ 2885 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.366481 [ 2913 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.446045 [ 2926 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.469897 [ 2938 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.519131 [ 2942 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.722287 [ 2935 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.754280 [ 2954 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.756637 [ 2955 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.834342 [ 2959 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:50.843245 [ 2972 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.133483 [ 2943 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.371011 [ 2963 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.496462 [ 2967 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.496844 [ 2960 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.522853 [ 2969 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.726642 [ 2953 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.758343 [ 2979 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.760153 [ 2956 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.838710 [ 2968 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:51.847029 [ 2920 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.137204 [ 2983 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.277930 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.374671 [ 2982 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.556017 [ 2995 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.556967 [ 2984 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.558180 [ 2994 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.730352 [ 2990 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.762354 [ 2992 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.764102 [ 3010 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.842632 [ 3006 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:52.850706 [ 2910 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.141139 [ 3000 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.378928 [ 3001 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.560157 [ 3017 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.560541 [ 3025 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.561757 [ 3022 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.734343 [ 2981 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.769289 [ 3013 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.770887 [ 2989 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.845833 [ 3033 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:53.854178 [ 3005 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.144762 [ 3037 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.382717 [ 3015 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.563906 [ 3034 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.564738 [ 3002 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.565361 [ 3038 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.737716 [ 3043 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.772883 [ 3032 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.775768 [ 3047 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.849131 [ 3046 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:54.857476 [ 3030 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.147619 [ 3057 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.385881 [ 3045 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.567324 [ 3051 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.631588 [ 3061 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.637399 [ 3036 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.741972 [ 3060 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.775750 [ 3059 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.779017 [ 3059 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.852242 [ 3068 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:55.860679 [ 3048 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.150545 [ 3085 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.389285 [ 3082 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.577720 [ 3026 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.634460 [ 3081 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.640517 [ 3074 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.749485 [ 3100 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.778921 [ 3095 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.782312 [ 3095 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.856712 [ 3087 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:56.863415 [ 3029 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.153477 [ 3099 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.393061 [ 3073 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.460790 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.582359 [ 3115 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.637876 [ 3120 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.643893 [ 3110 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.753155 [ 3117 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.782670 [ 3044 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.785626 [ 3111 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.860330 [ 3088 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:57.866645 [ 3113 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.156855 [ 3127 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.477155 [ 3130 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.586014 [ 3128 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.664111 [ 3135 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.664958 [ 3125 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.757064 [ 3134 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.786630 [ 3137 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.789918 [ 3140 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.864058 [ 3142 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:58.878120 [ 3143 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.160104 [ 3141 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.480897 [ 3150 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.590644 [ 3148 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.667948 [ 3103 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.668474 [ 3145 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.760295 [ 3161 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.790108 [ 3158 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.793760 [ 3158 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.866967 [ 3167 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:49:59.881372 [ 3171 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.164126 [ 3179 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.484071 [ 3169 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.594138 [ 3153 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.671713 [ 3173 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.672612 [ 3180 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.765306 [ 3168 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.793852 [ 3192 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.797475 [ 3165 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.870421 [ 3187 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:00.885266 [ 3175 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.167985 [ 3191 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.487851 [ 3200 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.598245 [ 3189 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.674835 [ 3196 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.678681 [ 3196 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.768499 [ 3207 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.797685 [ 3214 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.801142 [ 3214 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.873989 [ 3202 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:01.888932 [ 3211 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.171559 [ 3204 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.491353 [ 3149 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.551809 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.603489 [ 3210 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.678816 [ 3151 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.682218 [ 3151 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.771950 [ 3226 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.801324 [ 3201 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.804932 [ 3206 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.877140 [ 3234 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:02.892118 [ 3157 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.174816 [ 3224 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.494531 [ 3155 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.607369 [ 3235 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.682378 [ 3239 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.685468 [ 3233 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.776710 [ 3215 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.804817 [ 3242 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.808469 [ 3238 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.880813 [ 3221 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:03.896170 [ 3241 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.178615 [ 3262 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.498002 [ 3265 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.686470 [ 3268 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.689233 [ 3274 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.700704 [ 3266 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.780899 [ 3264 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.808718 [ 3267 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.812108 [ 3282 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.884474 [ 3255 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:04.900363 [ 3269 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.182553 [ 2774 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.501915 [ 3257 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.690536 [ 3270 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.693063 [ 3261 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.706232 [ 3276 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.784885 [ 2779 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.812492 [ 2785 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.815285 [ 3147 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.888714 [ 2804 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:05.904282 [ 2772 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.185317 [ 3183 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.505329 [ 2788 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.693897 [ 2777 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.696222 [ 2795 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.709079 [ 2782 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.772461 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.788356 [ 2799 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.816126 [ 2781 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.818371 [ 2780 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.892478 [ 3212 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:06.907704 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.189196 [ 2809 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.510028 [ 2807 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.698629 [ 2817 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.700501 [ 3271 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.712918 [ 2815 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.791415 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.792413 [ 2784 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.820302 [ 2816 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.822055 [ 2814 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.896266 [ 2827 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:07.917349 [ 2821 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.192331 [ 2810 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.513761 [ 2832 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.556453 [ 3382 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {3d81872f-1b54-4b63-aeed-f859059173ca::202510_1_214_43}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.741149 [ 2818 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.741787 [ 2824 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.742887 [ 2837 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.796139 [ 2839 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.823799 [ 2849 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.825503 [ 2847 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.900637 [ 2850 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:08.921213 [ 2852 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.196262 [ 2860 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.520681 [ 2854 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.749009 [ 2841 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.753781 [ 2868 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.760477 [ 2844 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.804950 [ 2872 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.827406 [ 2858 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.829359 [ 2851 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.906676 [ 2876 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:09.928041 [ 2874 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.200061 [ 2879 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.524422 [ 2875 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.752972 [ 2865 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.757317 [ 2873 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.764386 [ 2888 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.809117 [ 2896 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.831466 [ 2882 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.833567 [ 2898 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.910675 [ 2889 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:10.936872 [ 2893 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.204587 [ 2791 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.528271 [ 2905 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.756756 [ 2915 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.761122 [ 2914 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.768046 [ 2880 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.812913 [ 2907 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.835253 [ 2901 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.837541 [ 2917 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:11.914703 [ 2918 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.018490 [ 2922 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.208044 [ 2925 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.531651 [ 2927 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.763246 [ 2909 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.764934 [ 2930 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.771681 [ 2936 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.816205 [ 2929 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.838918 [ 2932 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.841450 [ 2937 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.879492 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:12.917890 [ 2912 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.024453 [ 2926 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.211568 [ 2948 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.535130 [ 2954 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.767295 [ 2945 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.769244 [ 2959 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.775724 [ 2972 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.819554 [ 2958 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.842809 [ 2949 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.844949 [ 2943 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:13.921423 [ 2963 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.029873 [ 2964 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.215035 [ 2952 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.538849 [ 2978 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.771769 [ 2953 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.773720 [ 2979 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.779780 [ 2956 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.809452 [ 24853 ] {6f24fe8f-f124-4b14-873c-2b6dbe1a1c56} executeQuery: Code: 341. DB::Exception: Timeout: Cannot enqueue query on this replica, most likely because replica is busy with previous queue entries. (UNFINISHED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:45730) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: CREATE TABLE test_1_repl_01111_8.rmt_18445_9841_30839 (`n` int) ENGINE = ReplicatedMergeTree ORDER BY tuple() SETTINGS index_granularity = 62823, min_bytes_for_wide_part = 0, ratio_of_defaults_for_sparse_serialization = 1., replace_long_file_name_to_hash = true, max_file_name_length = 0, min_bytes_for_full_part_storage = 223356973, compact_parts_max_bytes_to_buffer = 387449808, compact_parts_max_granules_to_buffer = 12, compact_parts_merge_max_bytes_to_prefetch_part = 23014911, merge_max_block_size = 14381, 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 = 1260741917, index_granularity_bytes = 3600966, concurrent_part_removal_threshold = 24, allow_vertical_merges_from_compact_to_wide_parts = false, cache_populated_by_fetch = true, marks_compress_block_size = 90560, primary_key_compress_block_size = 89271), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:322: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db61a8 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:50:14.813329 [ 24853 ] {6f24fe8f-f124-4b14-873c-2b6dbe1a1c56} TCPHandler: Code: 341. DB::Exception: Timeout: Cannot enqueue query on this replica, most likely because replica is busy with previous queue entries. (UNFINISHED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception<>(int, FormatStringHelperImpl<>) @ 0x000000000aacc68e 4. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:322: DB::DatabaseReplicatedDDLWorker::tryEnqueueAndExecuteEntry(DB::DDLLogEntry&, std::shared_ptr) @ 0x0000000027db61a8 5. ./build_docker/./src/Databases/DatabaseReplicated.cpp:0: DB::DatabaseReplicated::tryEnqueueReplicatedDDL(std::shared_ptr const&, std::shared_ptr, DB::QueryFlags) @ 0x0000000027d6a4ab 6. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b991c 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 11. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 2025.10.23 23:50:14.824167 [ 2974 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.846509 [ 2968 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.848309 [ 2920 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:14.924926 [ 2983 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.073349 [ 2999 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.218013 [ 2982 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.542773 [ 2990 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.775431 [ 3003 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.777000 [ 2971 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.829063 [ 3006 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.829313 [ 2991 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.850163 [ 2996 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.860138 [ 2951 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:15.928622 [ 3000 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.076223 [ 3004 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.265192 [ 2993 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.363669 [ 18922 ] {a6b41fc6-9677-4c99-ae63-117b08a06402} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41682) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_11), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:50:16.378293 [ 18922 ] {a6b41fc6-9677-4c99-ae63-117b08a06402} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Merge. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:50:16.545497 [ 2989 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.778518 [ 3033 ] {} test_13.compression_codec_replicated1 (c870920c-f093-43cb-80d8-840f00120ece): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_replicated/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.780232 [ 3005 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.832042 [ 3024 ] {} test_13.compression_codec_multiple_replicated1 (92bfeea3-1baf-4cbe-9d3b-e7869ef5fd95): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.833634 [ 2998 ] {} test_13.compression_codec_multiple_replicated2 (d1dca462-eb3f-45f9-8f05-03dac0479094): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_13/test_00910/compression_codec_multiple/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.853430 [ 3031 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.863815 [ 3021 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:16.931828 [ 3037 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.079429 [ 3020 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.268288 [ 3038 ] {} test_13.concurrent_alter_add_drop_3 (7cc66b0e-9cfc-4208-9cfd-35b6d6bdd1ea): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/3). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.556054 [ 3032 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.856928 [ 3030 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.866307 [ 3046 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.867170 [ 3042 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.934532 [ 3056 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:17.944019 [ 3054 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.081803 [ 3057 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.186577 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.560246 [ 3061 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.860894 [ 3067 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.869390 [ 3060 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.870412 [ 3077 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.976922 [ 3059 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:18.977076 [ 3068 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.088610 [ 3052 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.564319 [ 3078 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.864667 [ 3096 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.872976 [ 3097 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.873945 [ 3100 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.981235 [ 3092 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:19.982018 [ 3079 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.092929 [ 3029 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.568411 [ 3099 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.868476 [ 3109 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.878021 [ 2975 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.878598 [ 3112 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.984206 [ 3102 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:20.985304 [ 3115 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.097064 [ 3110 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.571614 [ 3121 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.871577 [ 3131 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.881874 [ 3126 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.882598 [ 3133 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.987922 [ 3108 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:21.988577 [ 3128 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.100546 [ 3135 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.574577 [ 3134 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.874801 [ 3143 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.884958 [ 3146 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.886023 [ 3141 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.991768 [ 3150 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:22.992651 [ 3148 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.104855 [ 3103 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.274101 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.578657 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.878073 [ 3162 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.888037 [ 3178 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.888744 [ 3169 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.995417 [ 3185 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:23.995975 [ 3188 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.107657 [ 3180 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.582176 [ 3168 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.880827 [ 3186 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.890579 [ 3194 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.891001 [ 3139 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.998564 [ 3191 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:24.998736 [ 3166 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.110489 [ 3193 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.585515 [ 3207 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.884079 [ 3220 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.893608 [ 3204 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:25.894106 [ 3177 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.003165 [ 3190 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.004103 [ 3216 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.113238 [ 3149 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.588428 [ 3234 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.886901 [ 3224 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.896346 [ 3229 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:26.897013 [ 3155 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.005945 [ 3235 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.006725 [ 3213 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.116296 [ 3239 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.592600 [ 3221 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.890085 [ 3262 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.910999 [ 3247 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:27.911819 [ 3236 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.008406 [ 3227 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.008976 [ 3248 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.119307 [ 3254 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.453320 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.595930 [ 3264 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.893846 [ 3255 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.914504 [ 3269 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:28.915523 [ 2774 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.011927 [ 2773 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.012477 [ 2775 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.122445 [ 3275 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.599975 [ 3260 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.897450 [ 3273 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.918396 [ 2785 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:29.919507 [ 3147 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.015735 [ 2796 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.016542 [ 2790 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.126650 [ 2772 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.603273 [ 2789 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.900846 [ 2788 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.921904 [ 2777 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:30.922821 [ 2795 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.019947 [ 2800 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.020765 [ 2799 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.129639 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.614162 [ 2807 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.903514 [ 2815 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.926679 [ 2784 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:31.927456 [ 2816 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.022781 [ 2814 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.023721 [ 2831 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.132784 [ 2821 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.616629 [ 2835 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.906051 [ 2820 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.930781 [ 2822 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:32.931972 [ 2836 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.025929 [ 2838 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.030525 [ 2834 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.135387 [ 2828 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.527521 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.619636 [ 2855 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.909525 [ 2869 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.934122 [ 2866 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:33.935726 [ 2867 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.091595 [ 2846 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.099153 [ 2862 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.137900 [ 2870 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.631364 [ 2871 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.912614 [ 2859 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.938098 [ 2884 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:34.939181 [ 2887 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.096168 [ 2888 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.102823 [ 2882 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.141307 [ 2898 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.641014 [ 2900 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.915461 [ 2892 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.941741 [ 2877 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:35.941936 [ 2908 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.099669 [ 2899 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.106322 [ 2883 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.144602 [ 2794 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.645660 [ 2923 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.919173 [ 2931 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.946504 [ 2911 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:36.947596 [ 2916 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.109246 [ 2924 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.119808 [ 2919 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.147835 [ 2902 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.649367 [ 2909 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.922690 [ 2912 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.949819 [ 2885 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:37.951012 [ 2946 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.112676 [ 2942 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.122869 [ 2934 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.151181 [ 2940 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.653253 [ 2959 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.683965 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:38.935203 [ 2950 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.018032 [ 2949 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.019114 [ 2943 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.117962 [ 2963 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.126085 [ 2966 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.154741 [ 2957 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.657312 [ 2965 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:39.939059 [ 2956 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.021503 [ 2974 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.022753 [ 2987 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.121097 [ 2986 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.129212 [ 2983 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.157755 [ 2980 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.660156 [ 2977 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:40.942761 [ 2990 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.024548 [ 2992 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.025817 [ 3010 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.123469 [ 2971 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.181283 [ 3006 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.182333 [ 2996 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.663069 [ 3017 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:41.955271 [ 3027 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.028319 [ 3013 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.035695 [ 2981 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.126150 [ 3009 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.184003 [ 3033 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.184931 [ 3005 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.666812 [ 3037 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:42.958904 [ 3041 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.031420 [ 3020 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.127198 [ 3015 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.129121 [ 3028 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.188304 [ 3002 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.189655 [ 3038 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.669726 [ 3056 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.832972 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:43.963314 [ 3057 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.034493 [ 3023 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.130421 [ 3070 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.132101 [ 3049 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.191934 [ 3045 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.192801 [ 3011 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.673335 [ 3080 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:44.967068 [ 3068 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.038169 [ 3048 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.133453 [ 3052 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.135150 [ 3069 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.197081 [ 3047 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.198096 [ 3075 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.677394 [ 3078 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:45.970579 [ 3081 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.041546 [ 3100 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.136792 [ 3066 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.138388 [ 3092 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.200910 [ 3079 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.201657 [ 3095 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.680425 [ 2975 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:46.974473 [ 3073 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.045563 [ 3102 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.141425 [ 3120 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.141915 [ 3110 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.204723 [ 3044 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.205668 [ 3111 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.684308 [ 3106 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:47.978102 [ 3123 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.057112 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.145810 [ 3131 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.146573 [ 3126 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.208675 [ 3130 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.212682 [ 3130 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.688151 [ 3135 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:48.981411 [ 3142 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.060746 [ 3143 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.105755 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.149520 [ 3146 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.150109 [ 3141 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.212145 [ 3107 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.215636 [ 3107 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.691321 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:49.984129 [ 3171 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.064146 [ 3136 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.152655 [ 3176 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.152868 [ 3162 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.216193 [ 3169 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.219053 [ 3185 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.694792 [ 3118 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:50.987463 [ 3181 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.066949 [ 3175 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.155679 [ 3139 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.156521 [ 3191 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.219413 [ 3197 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.222051 [ 3193 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.698671 [ 3195 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:51.996822 [ 3208 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.078698 [ 3202 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.164215 [ 3220 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.164791 [ 3203 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.222979 [ 3204 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.225627 [ 3177 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:52.702761 [ 3226 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.007077 [ 3234 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.081026 [ 3157 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.167615 [ 3231 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.168407 [ 3223 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.225801 [ 3225 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.237767 [ 3229 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:53.706214 [ 3242 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.010361 [ 3221 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.083242 [ 3244 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.170580 [ 3259 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.172509 [ 3227 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.223835 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.228808 [ 3251 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.240410 [ 3254 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:54.710310 [ 3266 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.024560 [ 3269 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.086733 [ 2774 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.173904 [ 2775 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.175921 [ 3257 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.232243 [ 3275 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.253611 [ 3253 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:55.715002 [ 3278 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.027579 [ 3273 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.089401 [ 2785 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.177272 [ 3256 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.179484 [ 2772 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.306737 [ 3283 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.307218 [ 2798 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:56.717740 [ 2788 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.030768 [ 2780 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.092676 [ 2786 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.180411 [ 2776 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.182841 [ 2805 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.310063 [ 2813 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.310427 [ 2793 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:57.729052 [ 2816 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.034671 [ 2827 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.104821 [ 2823 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.184200 [ 2810 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.186486 [ 2829 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.313722 [ 2832 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.314184 [ 2820 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.732705 [ 2840 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:58.786683 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.037956 [ 2828 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.117654 [ 2839 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.188191 [ 2850 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.189556 [ 2852 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.316475 [ 2863 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.316893 [ 2857 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.354614 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:50:59.736095 [ 2842 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.042324 [ 2841 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.197135 [ 2851 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.198147 [ 2876 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.198932 [ 2874 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.319521 [ 2875 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.429171 [ 2848 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:00.741026 [ 2888 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.045992 [ 2889 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.200573 [ 2791 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.201696 [ 2903 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.202281 [ 2897 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.323210 [ 2892 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.432506 [ 2877 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:01.745037 [ 2878 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.049457 [ 2907 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.203821 [ 2901 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.205033 [ 2923 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.205696 [ 2925 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.381460 [ 2916 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.440164 [ 2919 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:02.748573 [ 2927 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.052722 [ 2802 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.212608 [ 2909 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.213141 [ 2930 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.213939 [ 2928 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.385245 [ 2932 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.444025 [ 2912 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:03.752147 [ 2926 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.070533 [ 2944 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.215966 [ 2941 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.216744 [ 2945 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.217153 [ 2959 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.388659 [ 2950 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.447411 [ 2943 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.476204 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:04.755707 [ 2963 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.073819 [ 2952 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.227629 [ 2960 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.228266 [ 2969 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.228727 [ 2965 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.391748 [ 2973 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.450770 [ 2953 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:05.758931 [ 2968 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.076985 [ 2988 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.231236 [ 2982 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.232154 [ 2994 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.232660 [ 2995 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.395074 [ 2992 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.454358 [ 2991 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:06.761998 [ 3004 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.080445 [ 3025 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.235457 [ 3027 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.235811 [ 3013 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.236723 [ 2981 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.398309 [ 3019 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.457360 [ 3012 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:07.777417 [ 3018 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.083340 [ 2998 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.239153 [ 3021 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.239959 [ 3020 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.258644 [ 3041 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.401370 [ 3034 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.460834 [ 3015 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:08.780188 [ 3043 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.086637 [ 3046 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.242002 [ 2997 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.242989 [ 3058 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.261855 [ 3054 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.404590 [ 3049 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.463951 [ 3062 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.603630 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:09.783479 [ 3036 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.090101 [ 3060 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.245550 [ 3068 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.246914 [ 3048 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.265028 [ 3065 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.408031 [ 3083 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.473666 [ 3084 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:10.786977 [ 3091 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.093407 [ 3089 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.249285 [ 3094 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.250333 [ 3026 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.268427 [ 3081 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.411068 [ 3097 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.534056 [ 3092 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:11.791144 [ 3093 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.096571 [ 3101 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.252723 [ 3114 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.253508 [ 3073 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.271385 [ 3102 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.414851 [ 3115 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.538552 [ 3111 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:12.795050 [ 3106 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.140973 [ 3122 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.255733 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.256521 [ 3131 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.274551 [ 3126 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.418439 [ 3130 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.543059 [ 3135 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:13.798686 [ 3137 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.144458 [ 3154 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.259756 [ 3107 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.260327 [ 3148 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.277471 [ 3103 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.422857 [ 3160 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.546857 [ 3159 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.707638 [ 9640 ] {} DDLWorker(test_1_repl_01111_8): Error on initialization of test_1_repl_01111_8: Code: 57. DB::Exception: Directory for table data store/d9e/d9e011bf-2c25-4262-acc1-405d5ac3a128/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007f7519d19ac3 17. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:14.802208 [ 3136 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.157619 [ 3178 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.263394 [ 3185 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.264098 [ 3188 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.288829 [ 3153 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.427079 [ 3118 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.551204 [ 3165 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:15.810026 [ 3184 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.160760 [ 3191 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.266228 [ 3187 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.267110 [ 3194 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.291929 [ 3197 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.430435 [ 3193 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.652165 [ 3189 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.818383 [ 3198 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:16.839764 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.164526 [ 3204 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.268901 [ 3216 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.270097 [ 3149 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.294731 [ 3222 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.433527 [ 3218 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.631594 [ 3177 ] {} DatabaseCatalog: Cannot drop tables. Will retry later.: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=4). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000286d17dc 8. ./contrib/llvm-project/libcxx/include/vector:590: DB::DatabaseCatalog::dropTableDataTask() @ 0x00000000286d20a6 9. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 11. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 12. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 14. asan_thread_start(void*) @ 0x000000000aa47059 15. ? @ 0x00007f7519d19ac3 16. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.656319 [ 3226 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:17.773879 [ 18922 ] {90513661-ebba-46db-974b-12c8646bc038} executeQuery: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:41686) (comment: 01111_create_drop_replicated_db_stress.sh) (in query: drop database if exists test_13), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:51:17.791992 [ 18922 ] {90513661-ebba-46db-974b-12c8646bc038} TCPHandler: Code: 48. DB::Exception: Truncate is not supported by storage Null. (NOT_IMPLEMENTED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::IStorage::truncate(std::shared_ptr const&, std::shared_ptr const&, std::shared_ptr, DB::TableExclusiveLockHolder&) @ 0x00000000260ed450 4. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:279: DB::InterpreterDropQuery::executeToTableImpl(std::shared_ptr const&, DB::ASTDropQuery&, std::shared_ptr&, StrongTypedef, DB::UUIDTag>&) @ 0x00000000291fefef 5. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:454: DB::InterpreterDropQuery::executeToDatabaseImpl(DB::ASTDropQuery const&, std::shared_ptr&, std::vector, DB::UUIDTag>, std::allocator, DB::UUIDTag>>>&) @ 0x0000000029203a8c 6. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:361: DB::InterpreterDropQuery::executeToDatabase(DB::ASTDropQuery const&) @ 0x00000000291fc617 7. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:0: DB::InterpreterDropQuery::executeSingleDropQuery(std::shared_ptr const&) @ 0x00000000291fa891 8. ./build_docker/./src/Interpreters/InterpreterDropQuery.cpp:68: DB::InterpreterDropQuery::execute() @ 0x00000000291fa16d 9. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 10. ./build_docker/./src/Interpreters/executeQuery.cpp:1397: DB::executeQuery(String const&, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum) @ 0x0000000029b3e0a5 11. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:612: DB::TCPHandler::runImpl() @ 0x000000002d19290c 12. ./build_docker/./src/Server/TCPHandler.cpp:2517: DB::TCPHandler::run() @ 0x000000002d1c6740 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:51:17.828267 [ 3201 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.214369 [ 3157 ] {} test_1_repl_01111_1.rmt_31552_1927_29306 (d9e011bf-2c25-4262-acc1-405d5ac3a128): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/d9e011bf-2c25-4262-acc1-405d5ac3a128/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.272371 [ 3231 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.273928 [ 3223 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.297941 [ 3224 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.436553 [ 3155 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.661533 [ 3239 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:18.832743 [ 3215 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.274904 [ 3262 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.276802 [ 3247 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.330740 [ 3259 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.439128 [ 3227 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.664992 [ 3251 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:19.836153 [ 3252 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.277684 [ 3267 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.279371 [ 3282 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.333495 [ 3255 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.441813 [ 2773 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.668083 [ 3270 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:20.839108 [ 2772 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.280022 [ 2788 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.281679 [ 2777 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.363041 [ 2782 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.444573 [ 2797 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.448608 [ 2811 ] {} test_1_repl_01111_8.rmt_5247_23925_7639 (30276cea-66f1-4432-8136-bd499816db34): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/30276cea-66f1-4432-8136-bd499816db34/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.671056 [ 2816 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:21.841720 [ 2831 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.282698 [ 2810 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.284293 [ 2829 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.366064 [ 2835 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.447261 [ 2832 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.674689 [ 2820 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:22.844928 [ 2838 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.285311 [ 2818 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.286713 [ 2828 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.368765 [ 2849 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.449827 [ 2839 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.678034 [ 2847 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:23.848631 [ 2863 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.288233 [ 2854 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.289443 [ 2866 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.371589 [ 2846 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.495271 [ 2844 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.680808 [ 2874 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:24.851611 [ 2875 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.292086 [ 2884 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.293133 [ 2861 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.374599 [ 2888 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.498226 [ 2898 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.683483 [ 2893 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:25.854597 [ 2791 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.295294 [ 2899 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.295989 [ 2883 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.377383 [ 2904 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.501121 [ 2905 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.687126 [ 2845 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:26.857640 [ 2880 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.298397 [ 2911 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.299426 [ 2916 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.379834 [ 2919 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.503730 [ 2939 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.690400 [ 2921 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:27.861214 [ 2930 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.301793 [ 2938 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.303124 [ 2942 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.383061 [ 2940 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.568220 [ 2954 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.693368 [ 2972 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:28.864916 [ 2958 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.305719 [ 2963 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.307741 [ 2966 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.386659 [ 2961 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.572467 [ 2964 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.697170 [ 2962 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:29.868389 [ 2973 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.310791 [ 2987 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.311466 [ 2968 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.390640 [ 2986 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.583506 [ 2980 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.759667 [ 2783 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:30.872358 [ 2977 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.314410 [ 2990 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.315016 [ 2991 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.394441 [ 2996 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.587096 [ 2970 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.764267 [ 2993 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:31.876520 [ 3017 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.319145 [ 3019 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.375522 [ 2989 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.398657 [ 3012 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.599773 [ 3018 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.768562 [ 3035 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:32.880681 [ 3024 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.323177 [ 3020 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.379118 [ 3041 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.401987 [ 2894 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.603219 [ 3028 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.771342 [ 3040 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:33.884577 [ 3053 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.326833 [ 3056 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.382776 [ 3054 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.405587 [ 3050 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.607559 [ 3070 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.775418 [ 3045 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:34.888940 [ 3051 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.331136 [ 3067 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.386539 [ 3060 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.408781 [ 3077 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.611315 [ 3069 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.778413 [ 3084 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:35.895829 [ 3086 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.334478 [ 3094 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.389573 [ 3096 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.412502 [ 3097 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.614696 [ 3092 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.784317 [ 3072 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:36.898650 [ 3093 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.337478 [ 3109 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.392717 [ 3101 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.415805 [ 2975 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.618101 [ 3102 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.787203 [ 3117 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:37.901162 [ 3111 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.340346 [ 3121 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.402491 [ 3105 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.419291 [ 3124 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.621318 [ 3123 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.790462 [ 3126 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:38.904391 [ 3108 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.344127 [ 3134 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.406124 [ 3140 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.429932 [ 3143 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.625063 [ 3141 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.793002 [ 3103 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:39.907640 [ 3170 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.347495 [ 3167 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.409484 [ 3136 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.436608 [ 3179 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.628457 [ 3178 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.797152 [ 3169 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:40.911190 [ 3153 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.351335 [ 3184 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.413357 [ 3175 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.440252 [ 3191 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.632135 [ 3187 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.800519 [ 3182 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:41.915404 [ 3200 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.355601 [ 3196 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.417806 [ 3198 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.444277 [ 3208 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.635537 [ 3211 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.804948 [ 3216 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:42.919190 [ 3149 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.358898 [ 3152 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.421629 [ 3234 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.448289 [ 3231 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.643526 [ 3225 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.809322 [ 3213 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:43.923223 [ 3233 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.363890 [ 3246 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.425063 [ 3244 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.451835 [ 3262 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.647308 [ 3259 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.870174 [ 3265 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:44.927405 [ 3251 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.367847 [ 3258 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.428757 [ 3268 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.455364 [ 3266 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.653210 [ 3263 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.877931 [ 3282 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:45.931659 [ 3269 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.372314 [ 3253 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.432477 [ 3270 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.459282 [ 3261 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.657598 [ 2779 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:46.882174 [ 3260 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.035594 [ 3147 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.376405 [ 2804 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.436162 [ 3256 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.463063 [ 2772 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.661943 [ 2806 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:47.885935 [ 2789 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.039968 [ 2795 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.380615 [ 2780 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.440160 [ 2809 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.466587 [ 2781 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.665971 [ 2813 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:48.889325 [ 2797 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.043827 [ 3271 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.384248 [ 2814 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.444003 [ 2831 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.472192 [ 2827 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.670555 [ 2808 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:49.892563 [ 2835 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.047320 [ 2832 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.388248 [ 2819 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.447559 [ 2837 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.475822 [ 2838 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.674322 [ 2828 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:50.896625 [ 2852 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.055305 [ 2855 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.442458 [ 2857 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.479784 [ 2866 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.550432 [ 2856 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.678434 [ 2870 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:51.900145 [ 2851 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.062304 [ 2874 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.445698 [ 2879 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.483293 [ 2871 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.553862 [ 2875 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.683406 [ 2884 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:52.903996 [ 2888 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.072568 [ 2896 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.448921 [ 2891 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.486105 [ 2893 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.556836 [ 2853 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.686613 [ 2903 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:53.907173 [ 2908 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.076061 [ 2794 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.452906 [ 2886 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.490410 [ 2915 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.560688 [ 2880 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.690415 [ 2918 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:54.911320 [ 2923 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.079246 [ 2911 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.456718 [ 2927 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.493692 [ 2906 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.564032 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.693679 [ 2933 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:55.921137 [ 2909 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.082657 [ 2936 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.460605 [ 2913 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.497713 [ 2946 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.567715 [ 2938 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.697637 [ 2934 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:56.924940 [ 2944 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.086702 [ 2935 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.464729 [ 2945 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.501795 [ 2959 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.577772 [ 2958 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.701665 [ 2947 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:57.929182 [ 2961 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.090482 [ 2962 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.477208 [ 2965 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.506077 [ 2978 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.581815 [ 2973 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.705614 [ 2956 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:58.932958 [ 2968 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.093747 [ 2999 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.480556 [ 2982 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.509528 [ 2994 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.585467 [ 2995 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.709158 [ 2985 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:51:59.936673 [ 3010 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.097701 [ 3003 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.485667 [ 2910 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.513383 [ 2970 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.589519 [ 3016 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.712601 [ 3000 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:00.940592 [ 3027 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.100961 [ 3019 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.490107 [ 3033 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.516983 [ 3018 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.592986 [ 3005 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.716308 [ 3035 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:01.944666 [ 3024 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.105025 [ 3039 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.493911 [ 3034 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.521274 [ 3028 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.596865 [ 3015 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.720380 [ 3032 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:02.948965 [ 3053 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.108140 [ 3046 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.498213 [ 3054 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.525149 [ 3050 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.600572 [ 3057 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.723599 [ 3071 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:03.952771 [ 3061 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.111561 [ 3080 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.501709 [ 3068 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.529159 [ 3048 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.603906 [ 3065 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.731399 [ 3052 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:04.960175 [ 3084 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.114780 [ 3085 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.505873 [ 3089 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.533410 [ 3094 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.607979 [ 3026 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.738078 [ 3097 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:05.964757 [ 3095 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.118435 [ 3072 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.515159 [ 3098 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.537740 [ 3076 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.611935 [ 3101 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.742245 [ 3112 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:06.969505 [ 3073 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.122736 [ 3110 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.519395 [ 3088 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.542224 [ 3113 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.616493 [ 3116 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.881364 [ 3122 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:07.973464 [ 3123 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.127614 [ 3133 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.523979 [ 3125 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.546629 [ 3144 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.620495 [ 3134 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.885169 [ 3143 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:08.977354 [ 3154 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.131803 [ 3148 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.527996 [ 3145 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.550654 [ 3170 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.624177 [ 3160 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.889555 [ 3171 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:09.981567 [ 3167 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.135851 [ 3179 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.531851 [ 3185 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.554327 [ 3153 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.628852 [ 3173 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.893778 [ 3138 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:10.985633 [ 3165 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.203189 [ 3186 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.536005 [ 3197 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.557788 [ 3193 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.631737 [ 3200 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.897394 [ 3172 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:11.989523 [ 3198 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.206702 [ 3214 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.539635 [ 3211 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.561411 [ 3203 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.634693 [ 3204 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.901333 [ 3219 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:12.993454 [ 3226 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.209916 [ 3151 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.543541 [ 3231 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.580908 [ 3225 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.638153 [ 3229 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.908484 [ 3155 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:13.997791 [ 3233 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.212965 [ 3242 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.547724 [ 3244 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.591716 [ 3262 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.642402 [ 3221 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:14.912260 [ 3252 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.001333 [ 3243 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.216489 [ 3258 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.551840 [ 3277 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.595553 [ 3264 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.646014 [ 3282 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:15.915900 [ 2774 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.011343 [ 3250 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.219846 [ 2779 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.555656 [ 3276 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.599642 [ 3272 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.649584 [ 3260 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:16.919681 [ 3228 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.015002 [ 2775 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.223730 [ 2804 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.560230 [ 2798 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.603129 [ 2806 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.653125 [ 2792 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:17.923514 [ 2788 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.018735 [ 2795 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.227905 [ 2780 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.563676 [ 3249 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.606658 [ 2809 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.734442 [ 2781 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:18.927205 [ 2797 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.021992 [ 3271 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.231182 [ 2816 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.567473 [ 2821 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.610151 [ 3281 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.738478 [ 2823 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:19.930898 [ 2835 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.025392 [ 2812 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.234685 [ 2836 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.572579 [ 2824 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.614149 [ 2818 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.835261 [ 2849 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:20.933818 [ 2839 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.028157 [ 2855 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.237729 [ 2863 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.576139 [ 2867 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.618592 [ 2846 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.839271 [ 2841 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:21.937264 [ 2872 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.031261 [ 2876 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.241430 [ 2879 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.579605 [ 2884 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.622678 [ 2861 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.842839 [ 2888 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:22.940590 [ 2898 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.124280 [ 2891 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.245184 [ 2853 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.582997 [ 2897 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.626110 [ 2890 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.846057 [ 2883 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:23.943688 [ 2905 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.126724 [ 2914 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.315985 [ 2907 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.587397 [ 2923 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.630147 [ 2925 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.849873 [ 2924 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:24.947720 [ 2906 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.129566 [ 2921 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.319984 [ 2928 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.591043 [ 2929 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.633201 [ 2937 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.855054 [ 2926 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:25.951451 [ 2942 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.132954 [ 2940 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.323843 [ 2954 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.594981 [ 2943 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.636830 [ 2947 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.858486 [ 2957 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:26.955390 [ 2967 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.136571 [ 2965 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.327406 [ 2978 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.606832 [ 2956 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.641129 [ 2968 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.862122 [ 2988 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:27.959359 [ 2982 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.140245 [ 2977 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.336929 [ 2976 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.610588 [ 2971 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.645855 [ 2990 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.865438 [ 2951 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:28.963010 [ 3007 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.143896 [ 3016 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.340952 [ 3008 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.613922 [ 3009 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.651571 [ 3033 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.869579 [ 3024 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:29.966705 [ 3020 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.147148 [ 3015 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.348802 [ 3038 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.617429 [ 3043 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.655056 [ 3030 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.873269 [ 3056 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:30.970144 [ 3050 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.169146 [ 3057 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.353728 [ 3070 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.620428 [ 3061 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.659169 [ 3036 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.877024 [ 3077 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:31.974078 [ 3068 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.188235 [ 3048 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.357452 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.624365 [ 3086 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.663373 [ 3091 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.880475 [ 3078 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:32.977600 [ 3094 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.191626 [ 3096 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.361875 [ 3095 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.627702 [ 3093 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.667390 [ 3076 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.884295 [ 3104 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:33.980803 [ 3112 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.195258 [ 3115 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.365478 [ 3044 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.631697 [ 3116 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.671196 [ 3106 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.895224 [ 3123 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:34.985018 [ 3132 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.198954 [ 3133 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.369105 [ 3108 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.635087 [ 3125 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.674682 [ 3134 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.900006 [ 3140 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:35.989567 [ 3143 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.202648 [ 3107 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.372646 [ 3163 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.637975 [ 3145 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.677633 [ 3159 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.906131 [ 3158 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:36.992311 [ 3167 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.022465 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.206202 [ 3179 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.376382 [ 3178 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.647128 [ 3185 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.680746 [ 3153 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:37.908967 [ 3118 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.000451 [ 3168 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.304959 [ 3187 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.448609 [ 3194 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.650567 [ 3199 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.684125 [ 3182 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.904354 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:38.911936 [ 3172 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.007705 [ 3196 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.308603 [ 3202 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.452978 [ 3211 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.653825 [ 3216 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.688099 [ 3190 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:39.915966 [ 3210 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.010677 [ 3177 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.312453 [ 3152 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.456470 [ 3205 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.659199 [ 3223 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.702463 [ 3225 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:40.920225 [ 3230 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.013916 [ 3239 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.315906 [ 3241 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.459710 [ 3262 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.664168 [ 3240 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.706530 [ 3259 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:41.924149 [ 3235 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.017463 [ 3251 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.319511 [ 3245 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.558004 [ 3274 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.668144 [ 3264 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.710203 [ 3282 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:42.929313 [ 2773 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.021299 [ 3250 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.323192 [ 3261 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.571285 [ 2785 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.672335 [ 3276 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.713714 [ 3260 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:43.932665 [ 2775 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.025111 [ 3147 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.247473 [ 3378 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {f031c251-ff48-4808-844a-5edfe9b82eeb::202510_1_220_160}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.326936 [ 2790 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.575298 [ 2803 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.677869 [ 2806 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.717577 [ 2789 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:44.936577 [ 2777 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.028862 [ 3212 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.330121 [ 3249 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.579014 [ 2809 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.681270 [ 2801 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.720895 [ 2799 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:45.940353 [ 3271 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.031309 [ 2815 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.333874 [ 2831 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.582688 [ 2823 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.685486 [ 2829 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.724820 [ 2787 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:46.943797 [ 2833 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.034329 [ 2812 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.337430 [ 2838 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.586510 [ 2824 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.689329 [ 2828 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.728753 [ 2849 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:47.948201 [ 2839 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.042030 [ 2847 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.340718 [ 2863 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.589604 [ 2867 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.702387 [ 2854 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.773969 [ 2856 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:48.951367 [ 2870 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.045258 [ 2872 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.343484 [ 2851 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.593093 [ 2859 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.706221 [ 2848 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.777378 [ 2861 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:49.954835 [ 2882 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.048788 [ 2896 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.346469 [ 2889 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.599317 [ 2791 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.710056 [ 2890 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.781543 [ 2877 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:50.959268 [ 2908 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.052635 [ 2883 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.349836 [ 2845 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.602959 [ 2918 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.713859 [ 2922 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:51.784863 [ 2917 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.057451 [ 2902 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.061500 [ 2916 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.353174 [ 2921 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.606195 [ 2909 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.808263 [ 2936 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:52.809022 [ 2929 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.061158 [ 2885 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.064529 [ 2885 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.356592 [ 2942 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.609839 [ 2935 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.811668 [ 2954 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:53.812594 [ 2941 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.068389 [ 2958 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.069698 [ 2950 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.360307 [ 2947 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.614810 [ 2967 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.815602 [ 2973 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:54.816781 [ 2979 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.072655 [ 2968 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.073479 [ 2920 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.364238 [ 2986 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.618172 [ 2987 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.818533 [ 2982 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:55.819784 [ 2994 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.076365 [ 2992 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.077027 [ 3010 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.367187 [ 3003 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.621434 [ 2910 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.821597 [ 3007 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:56.822803 [ 3004 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.080662 [ 3025 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.081298 [ 3022 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.370580 [ 3013 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.624893 [ 3009 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.824865 [ 3005 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:57.826107 [ 3035 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.084013 [ 2998 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.087802 [ 3031 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.374141 [ 3037 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.628668 [ 3020 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.828049 [ 2894 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:58.829429 [ 3034 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.087651 [ 3032 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.091704 [ 3043 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.377583 [ 3046 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.632435 [ 3054 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.831912 [ 3049 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:52:59.833315 [ 3023 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.094899 [ 3071 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.154036 [ 3011 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.380877 [ 3061 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.642850 [ 3077 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.835728 [ 3065 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:00.836529 [ 3059 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.097990 [ 3069 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.156799 [ 3083 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.384026 [ 3082 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.649264 [ 3078 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.838888 [ 3026 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:01.839351 [ 3081 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.100922 [ 3100 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.159392 [ 3092 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.387288 [ 3095 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.652930 [ 3066 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.842459 [ 3029 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:02.842985 [ 3093 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.103645 [ 3101 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.162936 [ 3109 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.468927 [ 3073 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.656575 [ 3110 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.848294 [ 3044 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:03.848876 [ 3088 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.107061 [ 3105 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.166127 [ 3127 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.472148 [ 3133 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.660373 [ 3135 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.851505 [ 3137 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:04.851773 [ 3140 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.110052 [ 3154 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.169038 [ 3107 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.475293 [ 3161 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.664719 [ 3164 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.855263 [ 3158 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:05.856718 [ 3171 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.113691 [ 3162 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.172756 [ 3178 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.486135 [ 3173 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.726065 [ 3192 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.859938 [ 3181 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:06.860788 [ 3168 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.117178 [ 3138 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.176000 [ 3187 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.489927 [ 3166 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.649934 [ 3385 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_305_416_23}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=10, jobs=1). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007f7519d19ac3 28. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.730821 [ 3198 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.868085 [ 3214 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:07.868239 [ 3208 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.120075 [ 3203 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.179277 [ 3220 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.493261 [ 3219 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.734739 [ 3151 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.872408 [ 3234 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:08.873124 [ 3205 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.124014 [ 3225 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.182784 [ 3229 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.496600 [ 3215 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.762112 [ 3237 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.875893 [ 3221 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:09.890802 [ 3221 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.127029 [ 3235 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.187064 [ 3251 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.500266 [ 3258 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.766030 [ 3274 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.894426 [ 3264 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:10.906520 [ 3263 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.129502 [ 3250 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.190672 [ 3257 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.503652 [ 3270 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.769611 [ 3279 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.905782 [ 3272 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:11.910788 [ 3260 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.132746 [ 2775 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.194814 [ 3278 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.507044 [ 3283 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.772938 [ 3183 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.910232 [ 3280 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:12.914304 [ 2778 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.136617 [ 2777 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.199262 [ 2782 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.515277 [ 2800 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.776999 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.914323 [ 2813 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:13.919559 [ 2797 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.140626 [ 2811 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.241958 [ 2784 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.520728 [ 3281 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.780630 [ 2810 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.917765 [ 2826 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:14.923059 [ 2835 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.143446 [ 2822 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.257057 [ 2819 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.524339 [ 2824 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.785226 [ 2847 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.921407 [ 2855 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:15.935211 [ 2860 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.146835 [ 2825 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.260744 [ 2866 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.527968 [ 2846 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.789136 [ 2862 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.926016 [ 2868 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:16.939209 [ 2872 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.153389 [ 2879 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.270610 [ 2881 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.531069 [ 2884 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.792435 [ 2865 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.930402 [ 2888 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:17.943406 [ 2882 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.156881 [ 2873 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.274342 [ 2891 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.533967 [ 2903 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.796047 [ 2897 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.933224 [ 2794 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:18.946173 [ 2905 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.159606 [ 2878 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.277190 [ 2907 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.537693 [ 2901 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.799413 [ 2911 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.936377 [ 2916 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:19.949411 [ 2906 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.162357 [ 2895 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.280442 [ 2802 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.541090 [ 2937 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.802358 [ 2946 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.941411 [ 2938 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:20.952620 [ 2942 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.165600 [ 2944 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.360086 [ 2935 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.544950 [ 2941 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.806036 [ 2943 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.945051 [ 2963 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:21.956557 [ 2966 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.169001 [ 2957 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.364002 [ 2964 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.549154 [ 2967 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.810226 [ 2979 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.948908 [ 2987 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:22.960317 [ 2983 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.172670 [ 2980 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.377955 [ 2783 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.552580 [ 2984 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.813804 [ 2995 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.953020 [ 2976 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:23.964500 [ 2992 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.175813 [ 2996 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.382110 [ 2910 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.556533 [ 3001 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.817830 [ 3000 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.957093 [ 3025 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:24.968344 [ 3022 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.179838 [ 3013 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.385789 [ 3012 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.560366 [ 3014 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.821932 [ 3031 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.962068 [ 3021 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:25.971853 [ 3020 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.183550 [ 3034 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.389482 [ 3038 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.568700 [ 3030 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.825971 [ 2997 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.965883 [ 3054 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:26.975875 [ 3050 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.233809 [ 3049 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.393180 [ 3011 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.571723 [ 3063 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.829270 [ 3080 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.985615 [ 3060 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:27.985976 [ 3068 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.237244 [ 3065 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.396992 [ 3047 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.575489 [ 3086 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.833948 [ 3082 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.989028 [ 3064 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:28.989690 [ 3089 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.240888 [ 3096 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.400506 [ 3100 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.578999 [ 3095 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.845800 [ 3087 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.992902 [ 3076 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:29.993552 [ 3099 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.243642 [ 3114 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.436497 [ 3115 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.583591 [ 3088 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.849905 [ 3116 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.997236 [ 3121 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:30.997642 [ 3127 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.247089 [ 3124 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.439793 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.587364 [ 3133 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:31.854027 [ 3128 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.001538 [ 3144 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.002333 [ 3125 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.250892 [ 3140 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.484242 [ 3141 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.593350 [ 3107 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:32.857770 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.008187 [ 3164 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.009579 [ 3156 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.254063 [ 3136 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.487775 [ 3185 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.598223 [ 3173 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:33.861210 [ 3174 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.011969 [ 3180 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.012873 [ 3118 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.257544 [ 3168 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.492082 [ 3184 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.602376 [ 3139 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:34.865105 [ 3197 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.016006 [ 3199 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.016886 [ 3182 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.260799 [ 3195 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.495915 [ 3198 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.606303 [ 3208 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:35.870325 [ 3202 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.019853 [ 3149 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.020364 [ 3216 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.263952 [ 3217 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.499305 [ 3210 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.609405 [ 3152 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:36.873937 [ 3205 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.022995 [ 3229 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.023357 [ 3224 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.267733 [ 3233 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.503427 [ 3242 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.613556 [ 3238 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:37.948719 [ 3237 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.025845 [ 3262 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.026862 [ 3240 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.271136 [ 3259 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.522638 [ 3227 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.617221 [ 3265 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:38.958218 [ 3243 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.099514 [ 3266 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.099913 [ 3274 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.273869 [ 3282 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.526538 [ 3250 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.621744 [ 3257 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:39.961705 [ 3261 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.103786 [ 2785 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.105084 [ 3276 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.277344 [ 3260 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.530304 [ 3273 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:40.626319 [ 2804 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.011639 [ 2803 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.107741 [ 2798 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.108689 [ 2792 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.280699 [ 3280 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.533965 [ 2778 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:41.630295 [ 2795 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.014889 [ 3249 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.110987 [ 2799 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.111952 [ 2786 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.283851 [ 2813 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.538073 [ 2817 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:42.634870 [ 2811 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.017841 [ 2821 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.114491 [ 2808 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.115008 [ 3281 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.286999 [ 2823 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.541432 [ 2835 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:43.638073 [ 2812 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.020782 [ 2840 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.117861 [ 2818 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.119193 [ 2828 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.289925 [ 2849 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.544810 [ 2855 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:44.641893 [ 2860 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.024344 [ 2825 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.122536 [ 2830 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.123471 [ 2869 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.293881 [ 2846 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.548761 [ 2870 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:45.645800 [ 2868 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.028387 [ 2851 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.126471 [ 2859 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.127168 [ 2848 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.296496 [ 2861 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.552978 [ 2896 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:46.661053 [ 2873 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.032285 [ 2890 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.131432 [ 2897 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.131911 [ 2892 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.300258 [ 2794 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.557087 [ 2905 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:47.665850 [ 2878 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.036440 [ 2918 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.137207 [ 2923 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.137820 [ 2917 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.303398 [ 2919 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.561121 [ 2924 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:48.669473 [ 2916 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.039812 [ 2933 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.140545 [ 2802 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.141239 [ 2909 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.307715 [ 2932 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.564716 [ 2885 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:49.673259 [ 2938 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.043457 [ 2941 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.144108 [ 2959 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.144716 [ 2958 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.317236 [ 2972 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.568610 [ 2963 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:50.677511 [ 2957 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.047483 [ 2973 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.147950 [ 2979 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.148580 [ 2956 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.320733 [ 2920 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.572420 [ 2986 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:51.681635 [ 2783 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.059785 [ 2953 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.152984 [ 2994 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.153685 [ 2995 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.324346 [ 3010 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.576325 [ 2971 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:52.685535 [ 2990 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.070165 [ 3007 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.156430 [ 3001 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.157451 [ 3016 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.327958 [ 3017 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.579522 [ 2981 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:53.689088 [ 2989 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.077556 [ 3014 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.160174 [ 3035 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.160756 [ 3024 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.331230 [ 3031 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.582583 [ 3034 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:54.692373 [ 3028 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.081462 [ 3053 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.163713 [ 3042 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.164304 [ 2997 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.334828 [ 3056 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.586903 [ 3070 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:55.699570 [ 3071 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.085434 [ 3061 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.167721 [ 3036 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.168469 [ 3080 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.338760 [ 3077 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.590695 [ 3048 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:56.703381 [ 3069 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.088956 [ 3086 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.171472 [ 3090 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.172100 [ 3084 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.342378 [ 3082 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.594922 [ 3081 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:57.712915 [ 3092 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.092973 [ 3066 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.175378 [ 3029 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.175649 [ 3093 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.345501 [ 3099 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.607991 [ 3109 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:58.716986 [ 2975 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.099738 [ 3117 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.182197 [ 3111 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.185458 [ 3116 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.352903 [ 3121 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.611737 [ 3122 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:53:59.721250 [ 3132 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.103395 [ 3130 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.185631 [ 3129 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.188895 [ 3135 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.356179 [ 3137 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.615020 [ 3154 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:00.725692 [ 3119 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.111048 [ 3159 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.189440 [ 3136 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.192290 [ 3176 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.363966 [ 3162 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.618487 [ 3188 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:01.729172 [ 3169 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.114532 [ 3168 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.192802 [ 3186 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.202159 [ 3138 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.393745 [ 3197 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.623612 [ 3196 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:02.733118 [ 3195 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.117820 [ 3211 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.196324 [ 3220 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.205450 [ 3203 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.402401 [ 3222 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.627681 [ 3177 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:03.737278 [ 3151 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.121537 [ 3223 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.199943 [ 3224 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.209127 [ 3225 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.408573 [ 3230 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.631912 [ 3215 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:04.741440 [ 3242 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.124319 [ 3244 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.203355 [ 3259 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.212186 [ 3236 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.412410 [ 3265 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.635613 [ 3254 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:05.746491 [ 3252 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.136290 [ 3268 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.206895 [ 3277 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.216464 [ 3263 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.416080 [ 3269 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.639629 [ 3253 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:06.750314 [ 3270 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.140038 [ 3276 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.153062 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.210539 [ 3272 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.220835 [ 3260 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.420312 [ 3228 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.644595 [ 2804 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:07.754307 [ 2790 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.142942 [ 3283 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.217362 [ 2798 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.224347 [ 3183 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.423891 [ 2782 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.648208 [ 2781 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:08.757483 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.146482 [ 2797 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.221096 [ 2793 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.227539 [ 3271 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.428015 [ 2814 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.652068 [ 3281 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:09.760920 [ 2810 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.149997 [ 2822 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.230720 [ 2820 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.231508 [ 2836 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.432178 [ 2824 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.655787 [ 2847 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:10.764914 [ 2855 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.154317 [ 2825 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.233974 [ 2866 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.235177 [ 2867 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.524243 [ 2842 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.658816 [ 2870 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:11.768487 [ 2872 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.156930 [ 2871 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.237913 [ 2851 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.238791 [ 2881 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.527365 [ 2864 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.665294 [ 2865 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:12.772225 [ 2896 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.160531 [ 2889 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.241674 [ 2791 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.242627 [ 2903 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.531042 [ 2892 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.668448 [ 2908 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:13.779370 [ 2883 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.172220 [ 2914 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.245651 [ 2907 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.246359 [ 2880 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.533889 [ 2923 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.671419 [ 2925 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:14.782972 [ 2911 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.175646 [ 2924 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.248963 [ 2921 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.249911 [ 2933 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.537516 [ 2930 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.674764 [ 2936 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:15.786530 [ 2895 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.183733 [ 2913 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.252718 [ 2885 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.253650 [ 2926 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.540762 [ 2955 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.678042 [ 2935 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:16.789912 [ 2941 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.193933 [ 2958 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.258931 [ 2950 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.259499 [ 2972 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.543158 [ 2966 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.680942 [ 2957 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:17.793037 [ 2952 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.196967 [ 2969 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.261879 [ 2973 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.262618 [ 2979 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.546031 [ 2920 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.684244 [ 2986 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:18.796064 [ 2987 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.200281 [ 2982 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.265427 [ 2995 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.265917 [ 2977 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.549614 [ 2976 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.688639 [ 2990 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:19.799325 [ 2991 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.203454 [ 3007 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.268949 [ 2993 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.269680 [ 3001 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.553275 [ 3027 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.692431 [ 3019 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:20.802830 [ 3009 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.206862 [ 3018 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.273306 [ 3014 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.273559 [ 3035 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.556307 [ 3021 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.697285 [ 2894 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:21.806109 [ 3041 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.210647 [ 3038 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.277316 [ 3040 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.278373 [ 3032 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.560283 [ 3042 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.701074 [ 3050 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:22.809884 [ 3049 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.214605 [ 3011 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.280869 [ 3061 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.281586 [ 3036 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.564006 [ 3077 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.704234 [ 3059 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:23.813343 [ 3069 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.217872 [ 3090 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.284283 [ 3084 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.285053 [ 3091 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.570948 [ 3078 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.707731 [ 3100 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:24.816766 [ 3095 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.231860 [ 3093 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.291143 [ 3076 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.291904 [ 3099 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.580378 [ 2975 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.711313 [ 3110 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:25.820704 [ 3117 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.235445 [ 3113 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.294851 [ 3121 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.295620 [ 3106 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.583841 [ 3105 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.715063 [ 3132 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:26.824166 [ 3108 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.238642 [ 3144 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.297487 [ 3134 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.298425 [ 3137 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.587168 [ 3146 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.760667 [ 3141 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:27.828037 [ 3107 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.241938 [ 3170 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.300662 [ 3161 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.301567 [ 3160 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.590605 [ 3156 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.764176 [ 3171 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:28.831791 [ 3176 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.245645 [ 3188 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.304448 [ 3169 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.305988 [ 3153 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.594174 [ 3174 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.768180 [ 3175 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:29.835120 [ 3184 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.249358 [ 3193 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.307793 [ 3199 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.323424 [ 3182 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.598938 [ 3195 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.771782 [ 3198 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:30.837961 [ 3207 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.252667 [ 3149 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.311116 [ 3204 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.326366 [ 3190 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.461185 [ 3381 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {372f956e-2e06-47b7-812f-c88f2e715011::202510_305_435_28}: Code: 241. DB::Exception: Memory tracker (for thread): fault injected (at specific point). (MEMORY_LIMIT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, char const*&&, char const*&&) @ 0x000000001ae001da 4. ./build_docker/./src/Common/MemoryTracker.cpp:187: MemoryTracker::injectFault() const @ 0x000000001adfcd7a 5. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::finish() @ 0x000000002cc46b05 6. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc4551b 7. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 8. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007f7519d19ac3 15. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.611412 [ 3151 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.774532 [ 3234 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:31.846902 [ 3157 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.259126 [ 3229 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.314046 [ 3224 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.329231 [ 3225 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.614460 [ 3239 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.778147 [ 3238 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:32.851135 [ 3246 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.262424 [ 3247 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.318099 [ 3236 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.333081 [ 3227 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.617889 [ 3254 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.781725 [ 3243 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:33.854845 [ 3266 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.266004 [ 3263 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.366106 [ 3267 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.367090 [ 3269 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.621874 [ 3255 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.785789 [ 3253 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:34.864587 [ 3270 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.320128 [ 3260 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.370578 [ 2775 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.371365 [ 3147 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.627992 [ 3256 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.789835 [ 2790 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:35.868300 [ 2772 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.323445 [ 3280 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.375439 [ 2789 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.376209 [ 2778 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.631618 [ 2795 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.793354 [ 2777 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:36.872129 [ 3249 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.326496 [ 2799 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.379046 [ 2813 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.380084 [ 2797 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.635397 [ 3271 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.797664 [ 2831 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:37.876030 [ 2827 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.330299 [ 3281 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.382111 [ 2823 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.383593 [ 2829 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.638739 [ 2826 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.801791 [ 2822 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:38.879671 [ 2820 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.333641 [ 2824 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.385569 [ 2818 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.387182 [ 2828 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.642113 [ 2855 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.805540 [ 2843 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:39.882881 [ 2825 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.340278 [ 2854 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.389038 [ 2846 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.390146 [ 2856 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.645580 [ 2872 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.809028 [ 2874 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:40.886058 [ 2876 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.343103 [ 2864 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.392762 [ 2884 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.393451 [ 2887 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.648978 [ 2861 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.811972 [ 2888 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:41.889721 [ 2882 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.346638 [ 2893 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.399310 [ 2853 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.465210 [ 2791 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.652723 [ 2877 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.817083 [ 2883 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:42.893122 [ 2886 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.350231 [ 2878 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.402708 [ 2845 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.469656 [ 2918 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.656130 [ 2925 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.820817 [ 2911 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:43.904236 [ 2931 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.355702 [ 2933 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.406324 [ 2802 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.473671 [ 2909 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.659984 [ 2928 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.825084 [ 2929 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:44.909000 [ 2913 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.372297 [ 2934 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.410099 [ 2944 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.477840 [ 2955 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.663364 [ 2941 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.912896 [ 2950 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:45.931841 [ 2972 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.376595 [ 2966 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.413387 [ 2961 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.482935 [ 2967 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.667255 [ 2960 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.916916 [ 2979 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:46.935451 [ 2956 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.379926 [ 2988 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.417251 [ 2984 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.549116 [ 2982 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.671466 [ 3003 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.925993 [ 2991 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:47.939480 [ 3006 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.383424 [ 2910 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.420952 [ 2970 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.552990 [ 3004 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.676156 [ 3016 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.928801 [ 3027 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:48.942372 [ 3022 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.386764 [ 3009 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.424546 [ 3012 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.556694 [ 3005 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.680327 [ 3035 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.932603 [ 3021 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:49.945741 [ 2894 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.391605 [ 3028 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.428853 [ 3038 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.561105 [ 3053 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.684119 [ 3046 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.936477 [ 3058 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:50.949450 [ 3054 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.395584 [ 3071 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.436671 [ 3045 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.564542 [ 3061 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.687648 [ 3077 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.951755 [ 3048 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:51.953545 [ 3052 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.399675 [ 3075 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.440321 [ 3083 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.568398 [ 3086 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.691187 [ 3085 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.955333 [ 3078 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:52.957719 [ 3094 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.403328 [ 3079 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.447596 [ 3095 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.572467 [ 3097 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.695148 [ 3066 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.959735 [ 3029 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:53.962063 [ 3093 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.407082 [ 3114 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.452807 [ 3120 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.580735 [ 3073 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.698597 [ 3044 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.963774 [ 3121 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:54.966106 [ 3106 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.417577 [ 3132 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.456375 [ 3131 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.584548 [ 3108 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.778645 [ 3129 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.967825 [ 3140 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:55.970149 [ 3142 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.420977 [ 3107 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.459837 [ 3148 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.588262 [ 3163 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.783792 [ 3170 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.971519 [ 3145 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:56.973631 [ 3159 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.424551 [ 3176 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.463109 [ 3167 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.591751 [ 3162 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.787099 [ 3188 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.974504 [ 3174 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:57.976405 [ 3180 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.427932 [ 3168 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.467402 [ 3139 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.594628 [ 3191 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.790627 [ 3193 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:58.977382 [ 3166 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.011184 [ 3182 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.432756 [ 3195 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.470997 [ 3208 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.597842 [ 3209 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.794077 [ 3203 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:54:59.981079 [ 3222 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.014477 [ 3218 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.442528 [ 3231 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.473879 [ 3223 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.601737 [ 3229 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.797774 [ 3155 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:00.984235 [ 3239 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.017909 [ 3215 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.446127 [ 3242 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.477275 [ 3238 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.604691 [ 3241 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.800490 [ 3236 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:01.987147 [ 3235 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.021081 [ 3265 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.449155 [ 3243 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.479889 [ 3266 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.607427 [ 3245 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.806003 [ 3277 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:02.992397 [ 3269 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.023640 [ 2774 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.452045 [ 3275 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.482919 [ 3261 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.610375 [ 2779 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.809066 [ 3260 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:03.995772 [ 2775 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.026504 [ 3147 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.454610 [ 2772 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.485395 [ 3283 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.613770 [ 2806 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.812721 [ 3280 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:04.999402 [ 2778 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.029490 [ 2788 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.458687 [ 3249 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.488807 [ 2809 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.617458 [ 2801 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:05.816193 [ 2797 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.007318 [ 3271 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.032721 [ 2811 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.462352 [ 2827 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.492652 [ 2816 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.621216 [ 3281 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:06.819515 [ 2787 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.011017 [ 2826 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.036181 [ 2833 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.472442 [ 2837 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.495488 [ 2838 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.624747 [ 2819 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:07.823617 [ 2850 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.014910 [ 2847 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.039494 [ 2852 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.476151 [ 2857 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.499698 [ 2825 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.628282 [ 2867 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:08.827631 [ 2854 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.018438 [ 2842 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.043140 [ 2862 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.482625 [ 2879 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.503798 [ 2871 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.632156 [ 2881 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:09.831806 [ 2864 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.023156 [ 2887 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.047085 [ 2861 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.486202 [ 2893 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.507466 [ 2853 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.635944 [ 2903 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:10.835202 [ 2890 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.026039 [ 2877 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.056107 [ 2899 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.489796 [ 2915 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.511511 [ 2914 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.639841 [ 2845 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:11.838881 [ 2901 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.031435 [ 2923 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.059620 [ 2917 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.493346 [ 2919 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.514995 [ 2931 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.698452 [ 2927 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:12.843534 [ 2921 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.035032 [ 2802 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.152666 [ 2930 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.497115 [ 2946 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.521236 [ 2885 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.701001 [ 2934 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:13.852691 [ 2940 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.037672 [ 2954 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.156267 [ 2941 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.500662 [ 2949 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.524746 [ 2947 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.704197 [ 2961 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:14.866451 [ 2967 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.040792 [ 2969 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.170314 [ 2978 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.504359 [ 2920 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.528418 [ 2968 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.715123 [ 2986 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:15.870340 [ 2980 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.047032 [ 2988 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.173132 [ 2953 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.584462 [ 2995 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.585279 [ 2977 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.719905 [ 2992 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:16.873529 [ 3003 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.050766 [ 3006 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.176726 [ 2996 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.588574 [ 3001 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.589123 [ 3016 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.723818 [ 3027 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:17.876994 [ 2981 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.054690 [ 3013 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.180426 [ 2989 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.592884 [ 3005 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.593820 [ 3014 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.741250 [ 2998 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:18.880744 [ 3039 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.058031 [ 2894 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.184496 [ 3041 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.596960 [ 3040 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.598104 [ 3002 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.745587 [ 3053 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:19.884232 [ 2997 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.061566 [ 3058 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.188862 [ 3050 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.606275 [ 3071 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.606885 [ 3045 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.754353 [ 3011 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:20.888397 [ 3051 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.077360 [ 3067 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.191862 [ 3068 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.610691 [ 3075 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.609833 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.757846 [ 3083 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:21.891714 [ 3084 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.080991 [ 3089 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.195139 [ 3094 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.614177 [ 3096 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.619540 [ 3074 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.761571 [ 3079 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:22.895403 [ 3095 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.083624 [ 3066 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.198089 [ 3087 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.617772 [ 3099 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.623364 [ 3104 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.765450 [ 3109 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:23.899284 [ 3114 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.086467 [ 3120 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.201150 [ 3115 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.621240 [ 3116 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.626772 [ 3121 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.769006 [ 3124 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:24.902629 [ 3132 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.090018 [ 3126 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.275019 [ 3108 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.624117 [ 3137 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.629927 [ 3140 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.772331 [ 3142 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:25.907972 [ 3143 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.093366 [ 3119 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.278015 [ 3148 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.627880 [ 3170 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.633264 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.776523 [ 3145 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:26.911665 [ 3158 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.097156 [ 3136 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.281790 [ 3179 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.631785 [ 3188 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.637432 [ 3169 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.780823 [ 3118 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:27.915384 [ 3186 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.101182 [ 3138 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.316190 [ 3139 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.635227 [ 3199 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.644423 [ 3199 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.788828 [ 3172 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:28.918926 [ 3196 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.104543 [ 3208 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.319258 [ 3209 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.637936 [ 3203 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.653294 [ 3216 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.799642 [ 3190 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:29.922526 [ 3218 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.108081 [ 3217 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.323126 [ 3210 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.641912 [ 3205 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.656469 [ 3231 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.803943 [ 3229 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:30.927907 [ 3225 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.111870 [ 3233 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.326462 [ 3215 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.645431 [ 3237 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.660233 [ 3246 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.808129 [ 3241 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:31.931822 [ 3244 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.125192 [ 3235 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.329753 [ 3252 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.649218 [ 3274 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.663597 [ 3245 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.811752 [ 3277 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:32.935300 [ 3263 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.128871 [ 2774 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.332539 [ 3253 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.667290 [ 3261 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.732858 [ 3270 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.815616 [ 2785 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:33.938117 [ 3279 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.132441 [ 3228 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.336479 [ 3147 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.671525 [ 3256 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.736564 [ 2772 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.819116 [ 2803 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:34.941720 [ 2798 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.136036 [ 2789 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.343380 [ 2778 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.675918 [ 2777 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.740495 [ 3249 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.823518 [ 2780 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:35.945630 [ 2800 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.140250 [ 2801 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.347119 [ 2813 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.683157 [ 2815 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.745245 [ 2814 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.836226 [ 2831 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:36.949494 [ 2808 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.144675 [ 2823 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.350779 [ 2810 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.686880 [ 2812 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.749200 [ 2820 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.840331 [ 2837 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:37.952870 [ 2819 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.148373 [ 2818 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.354017 [ 2849 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.693389 [ 2852 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.753670 [ 2839 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.843773 [ 2860 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:38.956637 [ 2857 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.226858 [ 2825 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.357247 [ 2854 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.696250 [ 2862 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.757967 [ 2870 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.850972 [ 2844 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:39.960348 [ 2858 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.230423 [ 2875 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.361345 [ 2859 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.700007 [ 2861 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.767855 [ 2865 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.854452 [ 2888 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:40.964292 [ 2873 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.233621 [ 2893 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.366086 [ 2791 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.703825 [ 2897 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.771291 [ 2892 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.859244 [ 2877 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:41.967830 [ 2794 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.240862 [ 2915 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.368891 [ 2845 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.717623 [ 2925 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.775293 [ 2922 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.873104 [ 2919 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:42.971176 [ 2931 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.244630 [ 2927 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.372441 [ 2921 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.721622 [ 2909 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.778944 [ 2930 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:43.877336 [ 2936 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.020775 [ 2932 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.247993 [ 2946 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.383383 [ 2926 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.724845 [ 2934 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.782688 [ 2944 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:44.880773 [ 2935 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.061912 [ 2945 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.251514 [ 2958 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.386993 [ 2963 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.728534 [ 2961 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.789832 [ 2957 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:45.884558 [ 2967 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.066158 [ 2965 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.255935 [ 2969 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.471434 [ 2978 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.732481 [ 2968 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.793920 [ 2986 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:46.889354 [ 2987 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.069800 [ 2999 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.268904 [ 2994 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.283605 [ 25324 ] {} 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. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception>&, String>(int, FormatStringHelperImpl>&>::type, std::type_identity::type>, std::basic_string_view>&, String&&) @ 0x0000000026f891da 4. ./build_docker/./src/Access/SettingsConstraints.cpp:368: DB::SettingsConstraints::Checker::check(DB::SettingChange&, DB::Field const&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f86dc0 5. ./build_docker/./src/Access/SettingsConstraints.cpp:288: DB::SettingsConstraints::checkImpl(DB::Settings const&, DB::SettingChange&, DB::SettingsConstraints::ReactionOnViolation, DB::SettingSource) const @ 0x0000000026f852b1 6. ./contrib/llvm-project/libcxx/include/__algorithm/find_if.h:25: DB::SettingsConstraints::check(DB::Settings const&, DB::SettingsChanges&, DB::SettingSource) const @ 0x0000000026f85884 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::Context::checkSettingsConstraintsWithLock(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028545841 8. ./src/Common/SharedMutexHelper.h:106: DB::Context::checkSettingsConstraints(DB::SettingsChanges&, DB::SettingSource) @ 0x0000000028546431 9. ./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&) @ 0x000000002d081ef9 10. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 11. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 12. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 13. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 14. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 15. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 16. asan_thread_start(void*) @ 0x000000000aa47059 17. ? @ 0x00007f7519d19ac3 18. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.475837 [ 2977 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.798300 [ 3010 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.798852 [ 3003 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:47.893458 [ 2971 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.073236 [ 2991 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.279536 [ 2970 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.480977 [ 3004 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.802582 [ 3016 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.803342 [ 3017 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:48.897033 [ 3025 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.077190 [ 2981 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.283044 [ 2989 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.484464 [ 3018 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.806705 [ 3024 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.807502 [ 2998 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:49.900755 [ 3021 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.080773 [ 3028 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.286589 [ 3040 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.488638 [ 3002 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.810115 [ 3042 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.811428 [ 2997 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:50.905481 [ 3058 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.085283 [ 3054 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.290451 [ 3057 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.491979 [ 3023 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.813655 [ 3063 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.814654 [ 3051 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:51.908777 [ 3036 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.140862 [ 3077 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.294100 [ 3068 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.495565 [ 3047 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.817642 [ 3069 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.818193 [ 3083 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:52.912967 [ 3085 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.144558 [ 3084 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.301657 [ 3082 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.498852 [ 3094 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.821112 [ 3074 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.821625 [ 3100 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:53.916970 [ 3079 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.148257 [ 3097 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.305331 [ 3087 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.501910 [ 3076 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.824412 [ 3109 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.825178 [ 2975 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:54.924211 [ 3120 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.152327 [ 3088 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.309629 [ 3116 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.507299 [ 3113 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.833991 [ 3123 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.834109 [ 3105 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:55.928235 [ 3132 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.155695 [ 3133 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.313133 [ 3128 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.510880 [ 3144 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.838114 [ 3140 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.839073 [ 3142 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:56.931838 [ 3141 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.159766 [ 3163 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.316689 [ 3160 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.518317 [ 3159 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.842062 [ 3136 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.842458 [ 3176 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:57.935296 [ 3179 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.163292 [ 3178 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.321250 [ 3162 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.522010 [ 3174 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.845618 [ 3186 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.847003 [ 3175 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:58.939190 [ 3165 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.170317 [ 3138 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.325062 [ 3191 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.525950 [ 3166 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.849225 [ 3200 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.850674 [ 3172 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:55:59.943276 [ 3196 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.173940 [ 3198 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.336686 [ 3208 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.530331 [ 3211 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.852271 [ 3203 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.856483 [ 3149 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:00.946805 [ 3190 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.189840 [ 3177 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.341004 [ 3210 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.534622 [ 3206 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.856758 [ 3152 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:01.859727 [ 3157 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.024045 [ 3205 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.193612 [ 3229 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.344227 [ 3155 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.540760 [ 3239 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.865244 [ 3242 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:02.866095 [ 3238 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.027763 [ 3240 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.197470 [ 3221 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.347270 [ 3247 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.543828 [ 3236 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.869133 [ 3251 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:03.870396 [ 3252 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.030583 [ 3277 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.200575 [ 3282 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.350033 [ 3267 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.547359 [ 2773 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.873252 [ 3275 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:04.874034 [ 3261 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.033466 [ 3279 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.203942 [ 3276 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.353493 [ 2796 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.551552 [ 3147 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.877445 [ 2804 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:05.877886 [ 3256 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.037033 [ 2803 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.207945 [ 2798 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.363846 [ 2792 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.555851 [ 2789 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.881140 [ 3212 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:06.881889 [ 3249 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.045092 [ 2800 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.212735 [ 2801 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.368005 [ 2786 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.560021 [ 2807 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.885292 [ 2817 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:07.886173 [ 2815 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.048092 [ 2814 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.216634 [ 2821 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.371575 [ 2808 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.564369 [ 3281 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.889780 [ 2826 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:08.891043 [ 2833 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.051953 [ 2832 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.221564 [ 2836 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.375227 [ 2819 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.568736 [ 2834 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.893940 [ 2849 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:09.896097 [ 2852 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.057096 [ 2855 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.225289 [ 2843 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.379897 [ 2830 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.571740 [ 2825 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.897500 [ 2866 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:10.899250 [ 2854 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.060420 [ 2841 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.228260 [ 2872 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.383908 [ 2871 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.575351 [ 2874 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.900893 [ 2861 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:11.902801 [ 2887 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.064240 [ 2865 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.231416 [ 2898 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.387305 [ 2889 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.578911 [ 2903 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.908717 [ 2877 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:12.909923 [ 2908 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.069259 [ 2904 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.239982 [ 2883 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.390600 [ 2878 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.582341 [ 2845 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.912663 [ 2923 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:13.913382 [ 2917 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.072449 [ 2922 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.244244 [ 2931 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.394460 [ 2927 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.585822 [ 2802 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.916240 [ 2936 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:14.954481 [ 2928 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.076744 [ 2929 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.247806 [ 2926 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.398309 [ 2938 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.589428 [ 2944 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.957337 [ 2954 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:15.972138 [ 2955 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.080074 [ 2941 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.250913 [ 2950 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.401115 [ 2949 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.598243 [ 2947 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.960217 [ 2957 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:16.975232 [ 2952 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.083287 [ 2962 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.260795 [ 2965 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.404030 [ 2969 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.601292 [ 2974 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.963181 [ 2987 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:17.978746 [ 2983 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.086081 [ 2999 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.265151 [ 2953 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.407354 [ 2994 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.604504 [ 3003 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.967370 [ 2991 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:18.983496 [ 3006 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.089604 [ 2996 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.268219 [ 3007 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.409945 [ 3001 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.607453 [ 3017 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.970831 [ 3022 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:19.987142 [ 2981 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.093188 [ 3019 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.271144 [ 3012 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.413475 [ 3005 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.610907 [ 2998 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.973501 [ 3020 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:20.990028 [ 2894 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.096044 [ 3037 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.279161 [ 3028 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.416597 [ 3032 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.614052 [ 3030 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.976557 [ 3054 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:21.992714 [ 3056 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.098869 [ 3070 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.283257 [ 3049 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.420948 [ 3062 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.626416 [ 3011 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.980165 [ 3067 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:22.995935 [ 3060 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.102592 [ 3077 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.286583 [ 3059 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.424735 [ 3065 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.630961 [ 3069 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:23.983621 [ 3091 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.000428 [ 3082 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.108148 [ 3089 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.289301 [ 3026 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.428393 [ 3100 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.637028 [ 3079 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:24.987834 [ 3066 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.009123 [ 3029 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.115414 [ 3076 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.293193 [ 3099 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.432277 [ 3114 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.640630 [ 3073 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:25.991011 [ 3113 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.012246 [ 3106 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.118651 [ 3124 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.296745 [ 3123 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.435629 [ 3131 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.643831 [ 3126 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:26.994191 [ 3144 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.015457 [ 3125 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.121838 [ 3140 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.299690 [ 3143 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.439541 [ 3141 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.648303 [ 3107 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:27.997708 [ 3170 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.026882 [ 3161 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.124691 [ 3145 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.302974 [ 3156 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.443300 [ 3176 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:28.652206 [ 3178 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.000841 [ 3162 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.029970 [ 3188 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.127736 [ 3153 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.306094 [ 3174 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.446459 [ 3118 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:29.656078 [ 3184 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.007089 [ 3139 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.035175 [ 3187 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.131145 [ 3194 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.309301 [ 3199 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.450144 [ 3197 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:30.659846 [ 3182 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.012189 [ 3198 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.038370 [ 3214 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.134672 [ 3208 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.313413 [ 3209 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.455372 [ 3203 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:31.663931 [ 3216 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.016240 [ 3226 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.041822 [ 3177 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.138506 [ 3210 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.404774 [ 3206 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.459914 [ 3157 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:32.668297 [ 3225 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.020151 [ 3215 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.046538 [ 3232 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.142053 [ 3242 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.408803 [ 3244 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.463150 [ 3221 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:33.672476 [ 3259 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.025836 [ 3265 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.050221 [ 3248 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.145898 [ 3251 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.412330 [ 3258 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.467179 [ 3266 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:34.676538 [ 3277 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.031578 [ 3250 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.053957 [ 2773 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.149220 [ 3253 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.419193 [ 2779 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.470168 [ 3270 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:35.680139 [ 3279 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.034618 [ 3228 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.065565 [ 2796 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.152779 [ 2775 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.422427 [ 2804 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.473203 [ 3256 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:36.683397 [ 2803 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.041438 [ 2798 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.068621 [ 3183 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.155992 [ 2789 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.425483 [ 2777 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.476812 [ 2782 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:37.687321 [ 2805 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.044826 [ 2800 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.071729 [ 2781 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.159400 [ 2801 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.428661 [ 2776 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.480047 [ 2817 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:38.691299 [ 2815 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.048674 [ 2811 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.075160 [ 2831 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.163254 [ 2821 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.452487 [ 2823 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.483608 [ 2810 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:39.694665 [ 2826 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.052287 [ 2836 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.079024 [ 2820 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.166584 [ 2819 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.456175 [ 2828 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.515797 [ 2850 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:40.699168 [ 2839 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.055705 [ 2857 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.082592 [ 2863 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.172099 [ 2869 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.459898 [ 2854 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.619805 [ 2856 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:41.702963 [ 2846 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.059554 [ 2872 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.086241 [ 2876 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.212376 [ 2871 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.463131 [ 2875 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.623137 [ 2864 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:42.706815 [ 2887 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.063888 [ 2896 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.090062 [ 2898 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.216125 [ 2889 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.466789 [ 2853 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.626421 [ 2903 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:43.710531 [ 2900 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.067280 [ 2892 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.099937 [ 2908 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.224459 [ 2886 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.470941 [ 2915 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.629760 [ 2845 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:44.714411 [ 2880 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.070512 [ 2925 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.103073 [ 2922 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.228072 [ 2919 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.474555 [ 2927 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.633174 [ 2933 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:45.717935 [ 2906 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.078084 [ 2928 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.106421 [ 2895 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.232088 [ 2937 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.478229 [ 2932 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.636463 [ 2926 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:46.721987 [ 2938 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.083589 [ 2940 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.148159 [ 2954 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.235964 [ 2941 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.482776 [ 2958 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.640525 [ 2950 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:47.725710 [ 2972 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.086168 [ 2957 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.150863 [ 2952 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.240788 [ 2962 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.486600 [ 2973 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.644319 [ 2979 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:48.729594 [ 2956 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.089222 [ 2986 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.157987 [ 2980 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.241846 [ 2783 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.487972 [ 3062 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.646049 [ 3011 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:49.730994 [ 3063 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.090254 [ 3133 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.159462 [ 3144 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.242637 [ 3125 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.488542 [ 3159 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.647060 [ 3162 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:50.731582 [ 3174 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.090936 [ 3189 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.160143 [ 3208 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.243372 [ 3222 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.489137 [ 3233 ] {} test_13.table_for_bad_alters (4964c6ef-1e2c-436d-a3f6-45759549cba4): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_bad_alters_zookeeper_long_test_13/table_for_bad_alters/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.647903 [ 3241 ] {} test_d4i092zk.test_table_replicated (0c92448e-b219-45b5-bd8c-8ac1c988a4a3): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_d4i092zk/test_table_replicated/replicas/1_replica). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:51.732103 [ 3247 ] {} test_11.rmt_25754_10294_9366 (3f69d1d8-8526-4429-a8e5-b2f1a56299ff): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/3f69d1d8-8526-4429-a8e5-b2f1a56299ff/s1/replicas/r1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.091703 [ 3250 ] {} test_13.concurrent_alter_add_drop_1 (b3892367-17c9-4d41-ac92-588957745fc0): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.160828 [ 3257 ] {} test_1.t_mutations_nondeterministic (1f0efd11-14f4-40f0-9fea-0a4605bdb7ec): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/test_1/02842_mutations_replace/replicas/1). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:56:52.247632 [ 3270 ] {} test_13.concurrent_alter_add_drop_2 (6f73694f-b7c4-4fce-aeae-5c7af8a5f0ac): void DB::StorageReplicatedMergeTree::mutationsFinalizingTask(): Code: 242. DB::Exception: Table is in readonly mode (replica path: /clickhouse/tables/01079_parallel_alter_add_drop_column_zookeeper_test_13/concurrent_alter_add_drop_column/replicas/2). (TABLE_IS_READ_ONLY), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type>, String const&) @ 0x000000000aabf3f4 4. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:0: DB::StorageReplicatedMergeTree::assertNotReadonly() const @ 0x000000002ba225c3 5. ./build_docker/./src/Storages/StorageReplicatedMergeTree.cpp:262: DB::StorageReplicatedMergeTree::mutationsFinalizingTask() @ 0x000000002bb0fa31 6. ./src/Common/Stopwatch.h:72: DB::BackgroundSchedulePoolTaskInfo::execute() @ 0x00000000271f0f70 7. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::BackgroundSchedulePool::threadFunction() @ 0x00000000271f6e7d 8. ./src/Common/ThreadPool.h:312: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl, StrongTypedef, char const*)::$_0>(DB::BackgroundSchedulePool::BackgroundSchedulePool(unsigned long, StrongTypedef, StrongTypedef, char const*)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x00000000271f8027 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 10. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 11. asan_thread_start(void*) @ 0x000000000aa47059 12. ? @ 0x00007f7519d19ac3 13. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:57:52.417773 [ 26622 ] {2229129e-3dca-48ae-91a1-f8fc2f1206b0} executeQuery: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.032240929 seconds, maximum: 60. (TIMEOUT_EXCEEDED) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:56990) (in query: SELECT sleepEachRow(( SELECT maxOrDefault(300 - elapsed) + 1 FROM system.processes WHERE query NOT LIKE '%FROM system.processes%' AND elapsed < 300 ) / 300) FROM numbers(300) FORMAT Null SETTINGS function_sleep_max_microseconds_per_block = 0 ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000278629ba 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027861124 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d365155 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364ae0 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 2025.10.23 23:57:52.418524 [ 26622 ] {2229129e-3dca-48ae-91a1-f8fc2f1206b0} TCPHandler: Code: 159. DB::Exception: Timeout exceeded: elapsed 60.032240929 seconds, maximum: 60. (TIMEOUT_EXCEEDED), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, double&&, double&&) @ 0x00000000278629ba 4. ./build_docker/./src/QueryPipeline/ExecutionSpeedLimits.cpp:111: DB::ExecutionSpeedLimits::checkTimeLimit(Stopwatch const&, DB::OverflowMode) const @ 0x0000000027861124 5. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:0: DB::PipelineExecutor::finalizeExecution() @ 0x000000002d365155 6. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:132: DB::PipelineExecutor::execute(unsigned long, bool) @ 0x000000002d364ae0 7. ./build_docker/./src/Processors/Executors/PullingAsyncPipelineExecutor.cpp:94: void std::__function::__policy_invoker::__call_impl::ThreadFromGlobalPoolImpl(DB::PullingAsyncPipelineExecutor::pull(DB::Chunk&, unsigned long)::$_0&&)::'lambda'(), void ()>>(std::__function::__policy_storage const*) @ 0x000000002d388497 8. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 9. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 10. asan_thread_start(void*) @ 0x000000000aa47059 11. ? @ 0x00007f7519d19ac3 12. ? @ 0x00007f7519dab850 2025.10.23 23:57:53.182204 [ 25324 ] {40b98dc7-7e25-4ffe-ab70-0b07e125e2e3} 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.10542.altinitytest (altinity build)) (from [::1]:41546) (in query: CREATE DATABASE IF NOT EXISTS test ), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000027d169b5 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x0000000027d165bb 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000027d15d39 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919a824 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 2025.10.23 23:57:53.183408 [ 25324 ] {40b98dc7-7e25-4ffe-ab70-0b07e125e2e3} DynamicQueryHandler: Code: 521. DB::ErrnoException: Cannot rename /var/lib/clickhouse/metadata/test.sql.tmp to /var/lib/clickhouse/metadata/test.sql because the second path already exists: , errno: 17, strerror: File exists. (ATOMIC_RENAME_FAIL), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: DB::ErrnoException::ErrnoException(int, FormatStringHelperImpl::type, std::type_identity::type>, String const&, String const&) @ 0x0000000027d169b5 4. ./build_docker/./src/Common/atomicRename.cpp:92: DB::renameat2(String const&, String const&, int) @ 0x0000000027d165bb 5. ./build_docker/./src/Common/atomicRename.cpp:213: DB::renameNoReplace(String const&, String const&) @ 0x0000000027d15d39 6. ./contrib/llvm-project/libcxx/include/string:1499: DB::InterpreterCreateQuery::createDatabase(DB::ASTCreateQuery&) @ 0x000000002919a824 7. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0258 8. ./build_docker/./src/Interpreters/executeQuery.cpp:0: DB::executeQueryImpl(char const*, char const*, std::shared_ptr, DB::QueryFlags, DB::QueryProcessingStage::Enum, DB::ReadBuffer*) @ 0x0000000029b44d1c 9. ./build_docker/./src/Interpreters/executeQuery.cpp:1529: DB::executeQuery(DB::ReadBuffer&, DB::WriteBuffer&, bool, std::shared_ptr, std::function, DB::QueryFlags, std::optional const&, std::function const&, std::optional const&)>) @ 0x0000000029b4b75f 10. ./build_docker/./src/Server/HTTPHandler.cpp:529: DB::HTTPHandler::processQuery(DB::HTTPServerRequest&, DB::HTMLForm&, DB::HTTPServerResponse&, DB::HTTPHandler::Output&, std::optional&, StrongTypedef const&) @ 0x000000002d082a91 11. ./build_docker/./src/Server/HTTPHandler.cpp:705: DB::HTTPHandler::handleRequest(DB::HTTPServerRequest&, DB::HTTPServerResponse&, StrongTypedef const&) @ 0x000000002d0898f9 12. ./build_docker/./src/Server/HTTP/HTTPServerConnection.cpp:0: DB::HTTPServerConnection::run() @ 0x000000002d1e8ad7 13. ./build_docker/./base/poco/Net/src/TCPServerConnection.cpp:57: Poco::Net::TCPServerConnection::start() @ 0x000000003454bcaf 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:48: Poco::Net::TCPServerDispatcher::run() @ 0x000000003454c897 15. ./build_docker/./base/poco/Foundation/src/ThreadPool.cpp:219: Poco::PooledThread::run() @ 0x000000003444efab 16. ./base/poco/Foundation/include/Poco/SharedPtr.h:231: Poco::ThreadImpl::runnableEntry(void*) @ 0x0000000034449108 17. asan_thread_start(void*) @ 0x000000000aa47059 18. ? @ 0x00007f7519d19ac3 19. ? @ 0x00007f7519dab850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:00.466140 [ 2717 ] {} Application: Closed all listening sockets. Waiting for 10 outstanding connections. 2025.10.23 23:58:05.379221 [ 2717 ] {} Application: Closed connections. But 10 remain. Tip: To increase wait time add to config: 60 2025.10.23 23:58:05.379363 [ 2717 ] {} Application: Will shutdown forcefully. 2025.10.23 23:58:07.698639 [ 26687 ] {} Context: Server was built with address sanitizer. It will work slowly. 2025.10.23 23:58:07.712075 [ 26687 ] {} Context: Server logging level is set to 'test' and performance is degraded. This cannot be used in production. 2025.10.23 23:58:07.712843 [ 26687 ] {} Context: Delay accounting is not enabled, OSIOWaitMicroseconds will not be gathered. You can enable it using `echo 1 > /proc/sys/kernel/task_delayacct` or by using sysctl. 2025.10.23 23:58:07.713430 [ 26687 ] {} Context: The setting 'allow_remote_fs_zero_copy_replication' is enabled for MergeTree tables. But the feature of 'zero-copy replication' is under development and is not ready for production. The usage of this feature can lead to data corruption and loss. The setting should be disabled in production. 2025.10.23 23:58:08.872774 [ 26687 ] {} KeeperServer: Got 1000000000000000 value for setting 'reserved_log_items' which is bigger than int32_t max value, lowering value to 2147483647. 2025.10.23 23:58:08.881925 [ 26687 ] {} RaftInstance: invalid election timeout lower bound detected, adjusted to 0 2025.10.23 23:58:08.881977 [ 26687 ] {} RaftInstance: invalid election timeout upper bound detected, adjusted to 0 2025.10.23 23:58:08.932748 [ 27280 ] {} RaftInstance: Election timeout, initiate leader election 2025.10.23 23:58:10.621526 [ 26687 ] {} Context: Table system.session_log is enabled. It's unreliable and may contain garbage. Do not use it for any kind of security monitoring. 2025.10.23 23:58:11.148908 [ 26687 ] {} loadMetadata: Removing temporary file /var/lib/clickhouse/metadata/test.sql.tmp 2025.10.23 23:58:11.464521 [ 27407 ] {} DDLWorker(test_11): Replica seems to be lost: our_log_ptr=38, max_log_ptr=38, local_digest=12992492148531318470, zk_digest=2082263696514667771 2025.10.23 23:58:11.465778 [ 27407 ] {} DatabaseReplicated (test_11): Will recover replica with staled log pointer 38 from log pointer 38 2025.10.23 23:58:11.530994 [ 27407 ] {} DDLWorker(test_11): Error on initialization of test_11: Code: 439. DB::Exception: Cannot schedule a task: failed to start the thread (threads=0, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./build_docker/./src/Common/ThreadPool.cpp:0: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af85a4d 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x00000000263a59ee 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c470388 8. ./contrib/llvm-project/libcxx/include/optional:260: DB::StorageMergeTree::StorageMergeTree(DB::StorageID const&, String const&, DB::StorageInMemoryMetadata const&, DB::LoadingStrictnessLevel, std::shared_ptr, String const&, DB::MergeTreeData::MergingParams const&, std::unique_ptr>) @ 0x000000002cbc2fc8 9. ./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>&&) @ 0x000000002cbc1b9a 10. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:962: DB::create(DB::StorageFactory::Arguments const&) @ 0x000000002cbb8258 11. ./build_docker/./src/Storages/StorageFactory.cpp:225: DB::StorageFactory::get(DB::ASTCreateQuery const&, String const&, std::shared_ptr, std::shared_ptr, DB::ColumnsDescription const&, DB::ConstraintsDescription const&, DB::LoadingStrictnessLevel) const @ 0x000000002b78acb3 12. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1718: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c60d4 13. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 14. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 15. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 16. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 17. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 18. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 19. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 20. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 21. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 22. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 23. asan_thread_start(void*) @ 0x000000000aa47059 24. ? @ 0x00007fe5d0a6cac3 25. ? @ 0x00007fe5d0afe850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:11.680706 [ 26692 ] {54439c6b-66d6-4985-9e7b-da0b28e9bcbb} executeQuery: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK) (version 24.8.14.10542.altinitytest (altinity build)) (from [::1]:42268) (in query: SELECT count() FROM system.build_options WHERE name = 'CXX_FLAGS' AND position('sanitize=address' IN value)), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007fe5d0a6cac3 15. ? @ 0x00007fe5d0afe850 2025.10.23 23:58:11.681679 [ 26692 ] {54439c6b-66d6-4985-9e7b-da0b28e9bcbb} TCPHandler: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=7, jobs=7). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002d367d6a 7. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:306: DB::PipelineExecutor::executeStepImpl(unsigned long, std::atomic*) @ 0x000000002d36675b 8. ./build_docker/./src/Processors/Executors/PipelineExecutor.cpp:381: void std::__function::__policy_invoker::__call_impl>(std::__function::__policy_storage const*) @ 0x000000002d3684d5 9. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 10. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 11. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 12. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 13. asan_thread_start(void*) @ 0x000000000aa47059 14. ? @ 0x00007fe5d0a6cac3 15. ? @ 0x00007fe5d0afe850 2025.10.23 23:58:16.534853 [ 27407 ] {} DDLWorker(test_11): Replica seems to be lost: our_log_ptr=38, max_log_ptr=38, local_digest=6382408541900378952, zk_digest=2082263696514667771 2025.10.23 23:58:16.534925 [ 27407 ] {} DatabaseReplicated (test_11): Will recover replica with staled log pointer 38 from log pointer 38 2025.10.23 23:58:16.633479 [ 27407 ] {} DDLWorker(test_11): Error on initialization of test_11: Code: 57. DB::Exception: Directory for table data store/1cf/1cf174b5-3fee-419b-8439-48d021a42adf/ already exists. (TABLE_ALREADY_EXISTS), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. DB::Exception::Exception(int, FormatStringHelperImpl::type, std::type_identity::type>, String&&, String&&) @ 0x000000000aa95e9a 4. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:1659: DB::InterpreterCreateQuery::doCreateTable(DB::ASTCreateQuery&, DB::InterpreterCreateQuery::TableProperties const&, std::unique_ptr>&, DB::LoadingStrictnessLevel) @ 0x00000000291c9198 5. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:0: DB::InterpreterCreateQuery::createTable(DB::ASTCreateQuery&) @ 0x00000000291b9a9c 6. ./build_docker/./src/Interpreters/InterpreterCreateQuery.cpp:2045: DB::InterpreterCreateQuery::execute() @ 0x00000000291d0295 7. ./build_docker/./src/Databases/DatabaseReplicated.cpp:1368: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&)::$_4::operator()() const @ 0x0000000027d7f0a4 8. ./contrib/llvm-project/libcxx/include/__iterator/wrap_iter.h:100: DB::DatabaseReplicated::recoverLostReplica(std::shared_ptr const&, unsigned int, unsigned int&) @ 0x0000000027d745b3 9. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeReplication() @ 0x0000000027daca7d 10. ./build_docker/./src/Databases/DatabaseReplicatedWorker.cpp:0: DB::DatabaseReplicatedDDLWorker::initializeMainThread() @ 0x0000000027da880b 11. ./build_docker/./src/Interpreters/DDLWorker.cpp:1156: DB::DDLWorker::runMainThread() @ 0x000000002867d45a 12. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x00000000286ab0ff 13. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 14. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 15. asan_thread_start(void*) @ 0x000000000aa47059 16. ? @ 0x00007fe5d0a6cac3 17. ? @ 0x00007fe5d0afe850 (version 24.8.14.10542.altinitytest (altinity build)) 2025.10.23 23:58:18.240724 [ 27317 ] {} MergeTreeBackgroundExecutor: Exception while executing background task {6d7bfeba-2878-4bef-86bb-b5da6ac05b55::202510_1_249_112}: Code: 439. DB::Exception: Cannot schedule a task: fault injected (threads=4, jobs=0). (CANNOT_SCHEDULE_TASK), Stack trace (when copying this message, always include the lines below): 0. ./contrib/llvm-project/libcxx/include/exception:141: Poco::Exception::Exception(String const&, int) @ 0x000000003436e514 1. ./build_docker/./src/Common/Exception.cpp:111: DB::Exception::Exception(DB::Exception::MessageMasked&&, int, bool) @ 0x000000001adb42c9 2. DB::Exception::Exception(PreformattedMessage&&, int) @ 0x000000000aa92445 3. ./src/Common/LoggingFormatStringHelpers.h:45: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool)::'lambda'(String const&)::operator()(String const&) const @ 0x000000001af8f157 4. ./contrib/llvm-project/libcxx/include/string:1499: void ThreadPoolImpl>::scheduleImpl(std::function, Priority, std::optional, bool) @ 0x000000001af84bd1 5. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000001af847a6 6. ./contrib/llvm-project/libcxx/include/__functional/function.h:818: ? @ 0x000000002c779c8b 7. ./contrib/llvm-project/libcxx/include/__functional/function.h:1197: ? @ 0x000000002c774498 8. ./build_docker/./src/Storages/MergeTree/MergeTreeMarksLoader.cpp:73: DB::MergeTreeMarksLoader::startAsyncLoad() @ 0x000000002c773e0b 9. ./build_docker/./src/Storages/MergeTree/MergeTreeReaderCompact.cpp:0: DB::MergeTreeReaderCompact::MergeTreeReaderCompact(std::shared_ptr, DB::NamesAndTypesList, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*, DB::MarkCache*, DB::MarkRanges, DB::MergeTreeReaderSettings, std::map, std::allocator>>, std::function const&, int) @ 0x000000002c7c2fe3 10. ./src/Storages/MergeTree/MergeTreeReaderCompactSingleBuffer.h:16: DB::MergeTreeReaderCompactSingleBuffer::MergeTreeReaderCompactSingleBuffer&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int>(std::shared_ptr&, DB::NamesAndTypesList const&, std::unordered_map, std::equal_to, std::allocator>> const&, std::shared_ptr const&, DB::UncompressedCache*&, DB::MarkCache*&, DB::MarkRanges const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&, int&&) @ 0x000000002c5eae41 11. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:714: DB::MergeTreeDataPartCompact::getReader(DB::NamesAndTypesList const&, std::shared_ptr const&, DB::MarkRanges const&, std::unordered_map, std::equal_to, std::allocator>> const&, DB::UncompressedCache*, DB::MarkCache*, std::shared_ptr const&, DB::MergeTreeReaderSettings const&, std::map, std::allocator>> const&, std::function const&) const @ 0x000000002c5e5157 12. ./build_docker/./src/Storages/MergeTree/MergeTreeSequentialSource.cpp:169: DB::MergeTreeSequentialSource::MergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, bool, bool, bool) @ 0x000000002c820510 13. ./contrib/llvm-project/libcxx/include/__memory/construct_at.h:35: DB::MergeTreeSequentialSource* std::construct_at[abi:v15007] const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional, bool, bool&, bool&, DB::MergeTreeSequentialSource*>(DB::MergeTreeSequentialSource*, DB::MergeTreeSequentialSourceType&, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr&, std::shared_ptr&, std::vector>&, std::optional&&, bool&&, bool&, bool&) @ 0x000000002c8273ef 14. ./contrib/llvm-project/libcxx/include/__memory/allocator_traits.h:298: DB::createMergeTreeSequentialSource(DB::MergeTreeSequentialSourceType, DB::MergeTreeData const&, std::shared_ptr const&, std::shared_ptr, std::shared_ptr, std::vector>, std::optional, std::shared_ptr>, bool, bool, bool) @ 0x000000002c8249f2 15. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:1136: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::createMergedStream() @ 0x000000002c3ef1d9 16. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::prepare() @ 0x000000002c3e8676 17. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:534: DB::MergeTask::ExecuteAndFinalizeHorizontalPart::execute() @ 0x000000002c3f48f9 18. ./build_docker/./src/Storages/MergeTree/MergeTask.cpp:0: DB::MergeTask::execute() @ 0x000000002c40155e 19. ./build_docker/./src/Storages/MergeTree/MergePlainMergeTreeTask.cpp:0: DB::MergePlainMergeTreeTask::executeStep() @ 0x000000002cc45560 20. ./build_docker/./src/Storages/MergeTree/MergeTreeBackgroundExecutor.cpp:298: DB::MergeTreeBackgroundExecutor::routine(std::shared_ptr) @ 0x000000002c43a088 21. ./contrib/llvm-project/libcxx/include/__memory/shared_ptr.h:701: DB::MergeTreeBackgroundExecutor::threadFunction() @ 0x000000002c43b7d5 22. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af82b50 23. ./contrib/llvm-project/libcxx/include/__functional/invoke.h:0: ? @ 0x000000001af8e7ff 24. ./contrib/llvm-project/libcxx/include/__functional/function.h:0: ? @ 0x000000001af7dcb2 25. ./contrib/llvm-project/libcxx/include/__memory/unique_ptr.h:302: void* std::__thread_proxy[abi:v15007]>, void (ThreadPoolImpl::ThreadFromThreadPool::*)(), ThreadPoolImpl::ThreadFromThreadPool*>>(void*) @ 0x000000001af8a0b5 26. asan_thread_start(void*) @ 0x000000000aa47059 27. ? @ 0x00007fe5d0a6cac3 28. ? @ 0x00007fe5d0afe850 (version 24.8.14.10542.altinitytest (altinity build))